You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by jr...@apache.org on 2018/05/01 13:44:51 UTC

[01/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Repository: qpid-site
Updated Branches:
  refs/heads/asf-site b243c26c3 -> 701caf213


http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_flow_control_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_flow_control_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_flow_control_8cpp-example.html
index f7bc22d..e1a509a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_flow_control_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_flow_control_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('multithreaded_client_flow_control_8cpp
 </div><!--header-->
 <div class="contents">
 <p>A multithreaded sender and receiver enhanced for flow control.<b>Requires C++11</b></p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// C++11 or greater</span></div><div class="line"><span class="comment">//</span></div><d
 iv class="line"><span class="comment">// A multi-threaded client that sends and receives messages from multiple AMQP</span></div><div class="line"><span class="comment">// addresses.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Demonstrates how to:</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// - implement proton handlers that interact with user threads safely</span></div><div class="line"><span class="comment">// - block sender threads to respect AMQP flow control</span></div><div class="line"><span class="comment">// - use AMQP flow control to limit message buffering for receivers threads</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// We define sender and receiver classes with simple, thread-safe blocking</span></div><div class="line"><span class="comment">// send() and receive() functions.</s
 pan></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// These classes are also privately proton::message_handler instances. They use</span></div><div class="line"><span class="comment">// the thread-safe proton::work_queue and standard C++ synchronization (std::mutex</span></div><div class="line"><span class="comment">// etc.) to pass messages between user and proton::container threads.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// NOTE: no proper error handling</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code"
  href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver_8hpp.html">proton/receiver.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender_8hpp.html">proton/sender.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class
 ="preprocessor">#include &lt;atomic&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;condition_variable&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;mutex&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;queue&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;sstream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line"></div><div class="line"><span class="comment">// Lock output from threads to avoid scramblin</span></div><div class="line">std::mutex out_lock;</div><div class="line"><span class="preprocessor">#define OUT(x) do { std::lock_guard&lt;std::mutex&gt; l(out_lock); x; } while (false)</span></div><div class="line"></div><div class="line"><span class="
 comment">// A thread-safe sending connection that blocks sending threads when there</span></div><div class="line"><span class="comment">// is no AMQP credit to send messages.</span></div><div class="line"><span class="keyword">class </span>sender : <span class="keyword">private</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="comment">// Only used in proton handler thread</span></div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line"></div><div class="line">    <span class="comment">// Shared by proton and user threads, protected by lock_</span></div><div class="line">    std::mutex lock_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> *work_queue_;</div><div class="line">    std::condition_variable sender_ready
 _;</div><div class="line">    <span class="keywordtype">int</span> queued_;                       <span class="comment">// Queued messages waiting to be sent</span></div><div class="line">    <span class="keywordtype">int</span> credit_;                       <span class="comment">// AMQP credit - number of messages we can send</span></div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    sender(<a name="_a3"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont, <span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address)</div><div class="line">        : work_queue_(0), queued_(0), credit_(0)</div><div class="line">    {</div><div class="line">        cont.<a name="a4"></a><a class="code" href="classproton_1_1container.html#adfbfd13668611a525bb44328d7a3b1e8">open_sender</a>(url+<span class="stringliteral">&quot;/&quot;</span>+address,
  <a name="_a5"></a><a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a>().handler(*<span class="keyword">this</span>));</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> send(<span class="keyword">const</span> <a name="_a6"></a><a class="code" href="classproton_1_1message.html">proton::message</a>&amp; m) {</div><div class="line">        {</div><div class="line">            std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">            <span class="comment">// Don&#39;t queue up more messages than we have credit for</span></div><div class="line">            <span class="keywordflow">while</span> (!work_queue_ || queued_ &gt;= credit_) sender_ready_.wait(l);</div><div class="line">            ++queued_;</div><div class="line">        }</div><div class="line">        work_queue_-&gt;<a name=
 "a7"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { this-&gt;do_send(m); }); <span class="comment">// work_queue_ is thread safe</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        work_queue()-&gt;add([=]() { sender_.<a name="a8"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a9"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue() {</div><div class="line">        <s
 pan class="comment">// Wait till work_queue_ and sender_ are initialized.</span></div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (!work_queue_) sender_ready_.wait(l);</div><div class="line">        <span class="keywordflow">return</span> work_queue_;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// == messaging_handler overrides, only called in proton hander thread</span></div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a10"></a><a class="code" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">on_sender_open</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        <span class="comment">// Make sure sender_ and work_queue_ are set atomically</span></div><div cla
 ss="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        sender_ = s;</div><div class="line">        work_queue_ = &amp;s.<a name="a11"></a><a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a12"></a><a class="code" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        credit_ = s.<a name="a13"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();</div><div class="line">        sender_ready_.notify_all(); <span class="comment">// Notify senders we have credit</span></di
 v><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// work_queue work items is are automatically dequeued and called by proton</span></div><div class="line">    <span class="comment">// This function is called because it was queued by send()</span></div><div class="line">    <span class="keywordtype">void</span> do_send(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">proton::message</a>&amp; m) {</div><div class="line">        sender_.<a name="a14"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        --queued_;                    <span class="comment">// work item was consumed from the work_queue</span></div><div class="line">        credit_ = sender_.<a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();  
  <span class="comment">// update credit</span></div><div class="line">        sender_ready_.notify_all();       <span class="comment">// Notify senders we have space on queue</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a15"></a><a class="code" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">on_error</a>(<span class="keyword">const</span> <a name="_a16"></a><a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// A thread safe receiving connection that blocks receiving thre
 ads when there</span></div><div class="line"><span class="comment">// are no messages available, and maintains a bounded buffer of incoming</span></div><div class="line"><span class="comment">// messages by issuing AMQP credit only when there is space in the buffer.</span></div><div class="line"><span class="keyword">class </span>receiver : <span class="keyword">private</span> <a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">size_t</span> MAX_BUFFER = 100; <span class="comment">// Max number of buffered messages</span></div><div class="line"></div><div class="line">    <span class="comment">// Used in proton threads only</span></div><div class="line">    <a name="_a17"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver_;</div><div class="line"></div><div class="line">    <span class
 ="comment">// Used in proton and user threads, protected by lock_</span></div><div class="line">    std::mutex lock_;</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue_;</div><div class="line">    std::queue&lt;proton::message&gt; buffer_; <span class="comment">// Messages not yet returned by receive()</span></div><div class="line">    std::condition_variable can_receive_; <span class="comment">// Notify receivers of messages</span></div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line"></div><div class="line">    <span class="comment">// Connect to url</span></div><div class="line">    receiver(<a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont, <span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address)</div><div class="line">        : work_queue_()</div><div class="line"
 >    {</div><div class="line">        <span class="comment">// NOTE:credit_window(0) disables automatic flow control.</span></div><div class="line">        <span class="comment">// We will use flow control to match AMQP credit to buffer capacity.</span></div><div class="line">        cont.<a name="a18"></a><a class="code" href="classproton_1_1container.html#a15df75d582af4ed83f0ffab9dcce84bf">open_receiver</a>(url+<span class="stringliteral">&quot;/&quot;</span>+address, <a name="_a19"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>().credit_window(0),</div><div class="line">                           <a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a>().handler(*<span class="keyword">this</span>));</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe receive</span></div><div class="line">    <a class="code" href="classproton_1_1messa
 ge.html">proton::message</a> receive() {</div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="comment">// Wait for buffered messages</span></div><div class="line">        <span class="keywordflow">while</span> (!work_queue_ || buffer_.empty())</div><div class="line">            can_receive_.wait(l);</div><div class="line">        <a class="code" href="classproton_1_1message.html">proton::message</a> m = std::move(buffer_.front());</div><div class="line">        buffer_.pop();</div><div class="line">        <span class="comment">// Add a lambda to the work queue to call receive_done().</span></div><div class="line">        <span class="comment">// This will tell the handler to add more credit.</span></div><div class="line">        work_queue_-&gt;<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { this-&gt;receive_done(); });</div><div class="line">        <span cla
 ss="keywordflow">return</span> m;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">if</span> (work_queue_) work_queue_-&gt;<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([<span class="keyword">this</span>]() { this-&gt;receiver_.<a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="comment">// ==== The following are called by proton threads only.</span></div><div class="line"></div><div class="line">    <span class="keywordtyp
 e">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a>&amp; r)<span class="keyword"> override </span>{</div><div class="line">        receiver_ = r;</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        work_queue_ = &amp;receiver_.<a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">        receiver_.<a name="a20"></a><a class="code" href="classproton_1_1receiver.html#a84d3a001340d11201e03c6ed7c763641">add_credit</a>(MAX_BUFFER); <span class="comment">// Buffer is empty, initial credit is the limit</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_message(<a name="_a21"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m)<span 
 class="keyword"> override </span>{</div><div class="line">        <span class="comment">// Proton automatically reduces credit by 1 before calling on_message</span></div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        buffer_.push(m);</div><div class="line">        can_receive_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// called via work_queue</span></div><div class="line">    <span class="keywordtype">void</span> receive_done() {</div><div class="line">        <span class="comment">// Add 1 credit, a receiver has taken a message out of the buffer.</span></div><div class="line">        receiver_.<a class="code" href="classproton_1_1receiver.html#a84d3a001340d11201e03c6ed7c763641">add_credit</a>(1);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_error(<span class="keyword">const</span> 
 <a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// ==== Example code using the sender and receiver</span></div><div class="line"></div><div class="line"><span class="comment">// Send n messages</span></div><div class="line"><span class="keywordtype">void</span> send_thread(sender&amp; s, <span class="keywordtype">int</span> n) {</div><div class="line">    <span class="keyword">auto</span> <span class="keywordtype">id</span> = std::this_thread::get_id();</div><div class="line">    <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n; ++i) {</div><div
  class="line">        std::ostringstream ss;</div><div class="line">        ss &lt;&lt; std::this_thread::get_id() &lt;&lt; <span class="stringliteral">&quot;-&quot;</span> &lt;&lt; i;</div><div class="line">        s.send(<a class="code" href="classproton_1_1message.html">proton::message</a>(ss.str()));</div><div class="line">        OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; sent \&quot;&quot;</span> &lt;&lt; ss.str() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">    }</div><div class="line">    OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; sent &quot;</span> &lt;&lt; n &lt;&lt; std::endl);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">// Receive messages till atomic remaining count is 0.</span></div><div class="line"><span class="comment">// remaining is shared 
 among all receiving threads</span></div><div class="line"><span class="keywordtype">void</span> receive_thread(receiver&amp; r, std::atomic_int&amp; remaining) {</div><div class="line">    <span class="keyword">auto</span> <span class="keywordtype">id</span> = std::this_thread::get_id();</div><div class="line">    <span class="keywordtype">int</span> n = 0;</div><div class="line">    <span class="comment">// atomically check and decrement remaining *before* receiving.</span></div><div class="line">    <span class="comment">// If it is 0 or less then return, as there are no more</span></div><div class="line">    <span class="comment">// messages to receive so calling r.receive() would block forever.</span></div><div class="line">    <span class="keywordflow">while</span> (remaining-- &gt; 0) {</div><div class="line">        <span class="keyword">auto</span> m = r.receive();</div><div class="line">        ++n;</div><div class="line">        OUT(std::cout &lt;&lt; <span class="keywordt
 ype">id</span> &lt;&lt; <span class="stringliteral">&quot; received \&quot;&quot;</span> &lt;&lt; m.body() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">    }</div><div class="line">    OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; received &quot;</span> &lt;&lt; n &lt;&lt; <span class="stringliteral">&quot; messages&quot;</span> &lt;&lt; std::endl);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keyword">const</span> <span class="keywordtype">char</span> **argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        <span class="keywordflow">if</span> (argc != 5) {</div><div class="line">            std::cerr &lt;&lt;</div><div class="line">                <span class="stringliteral">&quot;Usage: &quot;</s
 pan> &lt;&lt; argv[0] &lt;&lt; <span class="stringliteral">&quot; MESSAGE-COUNT THREAD-COUNT URL\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;CONNECTION-URL: connection address, e.g.&#39;amqp://127.0.0.1&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;AMQP-ADDRESS: AMQP node address, e.g. &#39;examples&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;MESSAGE-COUNT: number of messages to send\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;THREAD-COUNT: number of sender/receiver thread pairs\n&quot;</span>;</div><div class="line">            <span class="keywordflow">return</span> 1;</div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *url = argv[1];</div><div class="line">        <span class="keyword">const
 </span> <span class="keywordtype">char</span> *address = argv[2];</div><div class="line">        <span class="keywordtype">int</span> n_messages = atoi(argv[3]);</div><div class="line">        <span class="keywordtype">int</span> n_threads = atoi(argv[4]);</div><div class="line">        <span class="keywordtype">int</span> count = n_messages * n_threads;</div><div class="line"></div><div class="line">        <span class="comment">// Total messages to be received, multiple receiver threads will decrement this.</span></div><div class="line">        std::atomic_int remaining(count);</div><div class="line"></div><div class="line">        <span class="comment">// Run the proton container</span></div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a> container;</div><div class="line">        <span class="keyword">auto</span> container_thread = std::thread([&amp;]() { container.<a name="a22"></a><a class="code" href="classproton_1_1containe
 r.html#a13a43e6d814de94978c515cb084873b1">run</a>(); });</div><div class="line"></div><div class="line">        <span class="comment">// A single sender and receiver to be shared by all the threads</span></div><div class="line">        sender send(container, url, address);</div><div class="line">        receiver recv(container, url, address);</div><div class="line"></div><div class="line">        <span class="comment">// Start receiver threads, then sender threads.</span></div><div class="line">        <span class="comment">// Starting receivers first gives all receivers a chance to compete for messages.</span></div><div class="line">        std::vector&lt;std::thread&gt; threads;</div><div class="line">        <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_threads; ++i)</div><div class="line">            threads.push_back(std::thread([&amp;]() { receive_thread(recv, remaining); }));</div><div class="line">        <span class="keywordflow"
 >for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_threads; ++i)</div><div class="line">            threads.push_back(std::thread([&amp;]() { send_thread(send, n_messages); }));</div><div class="line"></div><div class="line">        <span class="comment">// Wait for threads to finish</span></div><div class="line">        <span class="keywordflow">for</span> (<span class="keyword">auto</span>&amp; t : threads)</div><div class="line">            t.join();</div><div class="line">        send.close();</div><div class="line">        recv.close();</div><div class="line">        container_thread.join();</div><div class="line">        <span class="keywordflow">if</span> (remaining &gt; 0)</div><div class="line">            <span class="keywordflow">throw</span> std::runtime_error(<span class="stringliteral">&quot;not all messages were received&quot;</span>);</div><div class="line">        std::cout &lt;&lt; count &lt;&lt; <span class="stringliteral">&quot; messages sent and r
 eceived&quot;</span> &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// C++11 or greater</span></div><div class="line"><span class="comment">//</span></div><d
 iv class="line"><span class="comment">// A multi-threaded client that sends and receives messages from multiple AMQP</span></div><div class="line"><span class="comment">// addresses.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Demonstrates how to:</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// - implement proton handlers that interact with user threads safely</span></div><div class="line"><span class="comment">// - block sender threads to respect AMQP flow control</span></div><div class="line"><span class="comment">// - use AMQP flow control to limit message buffering for receivers threads</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// We define sender and receiver classes with simple, thread-safe blocking</span></div><div class="line"><span class="comment">// send() and receive() functions.</s
 pan></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// These classes are also privately proton::message_handler instances. They use</span></div><div class="line"><span class="comment">// the thread-safe proton::work_queue and standard C++ synchronization (std::mutex</span></div><div class="line"><span class="comment">// etc.) to pass messages between user and proton::container threads.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// NOTE: no proper error handling</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code"
  href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver_8hpp.html">proton/receiver.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender_8hpp.html">proton/sender.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class
 ="preprocessor">#include &lt;atomic&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;condition_variable&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;mutex&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;queue&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;sstream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line"></div><div class="line"><span class="comment">// Lock output from threads to avoid scrambling</span></div><div class="line">std::mutex out_lock;</div><div class="line"><span class="preprocessor">#define OUT(x) do { std::lock_guard&lt;std::mutex&gt; l(out_lock); x; } while (false)</span></div><div class="line"></div><div class="line"><span class=
 "comment">// A thread-safe sending connection that blocks sending threads when there</span></div><div class="line"><span class="comment">// is no AMQP credit to send messages.</span></div><div class="line"><span class="keyword">class </span>sender : <span class="keyword">private</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="comment">// Only used in proton handler thread</span></div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line"></div><div class="line">    <span class="comment">// Shared by proton and user threads, protected by lock_</span></div><div class="line">    std::mutex lock_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> *work_queue_;</div><div class="line">    std::condition_variable sender_read
 y_;</div><div class="line">    <span class="keywordtype">int</span> queued_;                       <span class="comment">// Queued messages waiting to be sent</span></div><div class="line">    <span class="keywordtype">int</span> credit_;                       <span class="comment">// AMQP credit - number of messages we can send</span></div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    sender(<a name="_a3"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont, <span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address)</div><div class="line">        : work_queue_(0), queued_(0), credit_(0)</div><div class="line">    {</div><div class="line">        cont.<a name="a4"></a><a class="code" href="classproton_1_1container.html#adfbfd13668611a525bb44328d7a3b1e8">open_sender</a>(url+<span class="stringliteral">&quot;/&quot;</span>+address
 , <a name="_a5"></a><a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a>().handler(*<span class="keyword">this</span>));</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> send(<span class="keyword">const</span> <a name="_a6"></a><a class="code" href="classproton_1_1message.html">proton::message</a>&amp; m) {</div><div class="line">        {</div><div class="line">            std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">            <span class="comment">// Don&#39;t queue up more messages than we have credit for</span></div><div class="line">            <span class="keywordflow">while</span> (!work_queue_ || queued_ &gt;= credit_) sender_ready_.wait(l);</div><div class="line">            ++queued_;</div><div class="line">        }</div><div class="line">        work_queue_-&gt;<a name
 ="a7"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { this-&gt;do_send(m); }); <span class="comment">// work_queue_ is thread safe</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        work_queue()-&gt;add([=]() { sender_.<a name="a8"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a9"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue() {</div><div class="line">        <
 span class="comment">// Wait till work_queue_ and sender_ are initialized.</span></div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (!work_queue_) sender_ready_.wait(l);</div><div class="line">        <span class="keywordflow">return</span> work_queue_;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// == messaging_handler overrides, only called in proton handler thread</span></div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a10"></a><a class="code" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">on_sender_open</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        <span class="comment">// Make sure sender_ and work_queue_ are set atomically</span></div><div c
 lass="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        sender_ = s;</div><div class="line">        work_queue_ = &amp;s.<a name="a11"></a><a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a12"></a><a class="code" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">on_sendable</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        credit_ = s.<a name="a13"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();</div><div class="line">        sender_ready_.notify_all(); <span class="comment">// Notify senders we have credit</span></
 div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// work_queue work items is are automatically dequeued and called by proton</span></div><div class="line">    <span class="comment">// This function is called because it was queued by send()</span></div><div class="line">    <span class="keywordtype">void</span> do_send(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">proton::message</a>&amp; m) {</div><div class="line">        sender_.<a name="a14"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        --queued_;                    <span class="comment">// work item was consumed from the work_queue</span></div><div class="line">        credit_ = sender_.<a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();
    <span class="comment">// update credit</span></div><div class="line">        sender_ready_.notify_all();       <span class="comment">// Notify senders we have space on queue</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a15"></a><a class="code" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">on_error</a>(<span class="keyword">const</span> <a name="_a16"></a><a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// A thread safe receiving connection that blocks receiving th
 reads when there</span></div><div class="line"><span class="comment">// are no messages available, and maintains a bounded buffer of incoming</span></div><div class="line"><span class="comment">// messages by issuing AMQP credit only when there is space in the buffer.</span></div><div class="line"><span class="keyword">class </span>receiver : <span class="keyword">private</span> <a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">size_t</span> MAX_BUFFER = 100; <span class="comment">// Max number of buffered messages</span></div><div class="line"></div><div class="line">    <span class="comment">// Used in proton threads only</span></div><div class="line">    <a name="_a17"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver_;</div><div class="line"></div><div class="line">    <span cla
 ss="comment">// Used in proton and user threads, protected by lock_</span></div><div class="line">    std::mutex lock_;</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue_;</div><div class="line">    std::queue&lt;proton::message&gt; buffer_; <span class="comment">// Messages not yet returned by receive()</span></div><div class="line">    std::condition_variable can_receive_; <span class="comment">// Notify receivers of messages</span></div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line"></div><div class="line">    <span class="comment">// Connect to url</span></div><div class="line">    receiver(<a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont, <span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address)</div><div class="line">        : work_queue_()</div><div class="lin
 e">    {</div><div class="line">        <span class="comment">// NOTE:credit_window(0) disables automatic flow control.</span></div><div class="line">        <span class="comment">// We will use flow control to match AMQP credit to buffer capacity.</span></div><div class="line">        cont.<a name="a18"></a><a class="code" href="classproton_1_1container.html#a15df75d582af4ed83f0ffab9dcce84bf">open_receiver</a>(url+<span class="stringliteral">&quot;/&quot;</span>+address, <a name="_a19"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>().credit_window(0),</div><div class="line">                           <a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a>().handler(*<span class="keyword">this</span>));</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe receive</span></div><div class="line">    <a class="code" href="classproton_1_1mes
 sage.html">proton::message</a> receive() {</div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="comment">// Wait for buffered messages</span></div><div class="line">        <span class="keywordflow">while</span> (!work_queue_ || buffer_.empty())</div><div class="line">            can_receive_.wait(l);</div><div class="line">        <a class="code" href="classproton_1_1message.html">proton::message</a> m = std::move(buffer_.front());</div><div class="line">        buffer_.pop();</div><div class="line">        <span class="comment">// Add a lambda to the work queue to call receive_done().</span></div><div class="line">        <span class="comment">// This will tell the handler to add more credit.</span></div><div class="line">        work_queue_-&gt;<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { this-&gt;receive_done(); });</div><div class="line">        <span c
 lass="keywordflow">return</span> m;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">if</span> (work_queue_) work_queue_-&gt;<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([<span class="keyword">this</span>]() { this-&gt;receiver_.<a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="comment">// ==== The following are called by proton threads only.</span></div><div class="line"></div><div class="line">    <span class="keywordt
 ype">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a>&amp; r)<span class="keyword"> override </span>{</div><div class="line">        receiver_ = r;</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        work_queue_ = &amp;receiver_.<a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">        receiver_.<a name="a20"></a><a class="code" href="classproton_1_1receiver.html#a84d3a001340d11201e03c6ed7c763641">add_credit</a>(MAX_BUFFER); <span class="comment">// Buffer is empty, initial credit is the limit</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_message(<a name="_a21"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m)<spa
 n class="keyword"> override </span>{</div><div class="line">        <span class="comment">// Proton automatically reduces credit by 1 before calling on_message</span></div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        buffer_.push(m);</div><div class="line">        can_receive_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// called via work_queue</span></div><div class="line">    <span class="keywordtype">void</span> receive_done() {</div><div class="line">        <span class="comment">// Add 1 credit, a receiver has taken a message out of the buffer.</span></div><div class="line">        receiver_.<a class="code" href="classproton_1_1receiver.html#a84d3a001340d11201e03c6ed7c763641">add_credit</a>(1);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_error(<span class="keyword">const</span
 > <a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// ==== Example code using the sender and receiver</span></div><div class="line"></div><div class="line"><span class="comment">// Send n messages</span></div><div class="line"><span class="keywordtype">void</span> send_thread(sender&amp; s, <span class="keywordtype">int</span> n) {</div><div class="line">    <span class="keyword">auto</span> <span class="keywordtype">id</span> = std::this_thread::get_id();</div><div class="line">    <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n; ++i) {</div><d
 iv class="line">        std::ostringstream ss;</div><div class="line">        ss &lt;&lt; std::this_thread::get_id() &lt;&lt; <span class="stringliteral">&quot;-&quot;</span> &lt;&lt; i;</div><div class="line">        s.send(<a class="code" href="classproton_1_1message.html">proton::message</a>(ss.str()));</div><div class="line">        OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; sent \&quot;&quot;</span> &lt;&lt; ss.str() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">    }</div><div class="line">    OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; sent &quot;</span> &lt;&lt; n &lt;&lt; std::endl);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">// Receive messages till atomic remaining count is 0.</span></div><div class="line"><span class="comment">// remaining is share
 d among all receiving threads</span></div><div class="line"><span class="keywordtype">void</span> receive_thread(receiver&amp; r, std::atomic_int&amp; remaining) {</div><div class="line">    <span class="keyword">auto</span> <span class="keywordtype">id</span> = std::this_thread::get_id();</div><div class="line">    <span class="keywordtype">int</span> n = 0;</div><div class="line">    <span class="comment">// atomically check and decrement remaining *before* receiving.</span></div><div class="line">    <span class="comment">// If it is 0 or less then return, as there are no more</span></div><div class="line">    <span class="comment">// messages to receive so calling r.receive() would block forever.</span></div><div class="line">    <span class="keywordflow">while</span> (remaining-- &gt; 0) {</div><div class="line">        <span class="keyword">auto</span> m = r.receive();</div><div class="line">        ++n;</div><div class="line">        OUT(std::cout &lt;&lt; <span class="keywor
 dtype">id</span> &lt;&lt; <span class="stringliteral">&quot; received \&quot;&quot;</span> &lt;&lt; m.body() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">    }</div><div class="line">    OUT(std::cout &lt;&lt; <span class="keywordtype">id</span> &lt;&lt; <span class="stringliteral">&quot; received &quot;</span> &lt;&lt; n &lt;&lt; <span class="stringliteral">&quot; messages&quot;</span> &lt;&lt; std::endl);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keyword">const</span> <span class="keywordtype">char</span> **argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        <span class="keywordflow">if</span> (argc != 5) {</div><div class="line">            std::cerr &lt;&lt;</div><div class="line">                <span class="stringliteral">&quot;Usage: &quot;<
 /span> &lt;&lt; argv[0] &lt;&lt; <span class="stringliteral">&quot; MESSAGE-COUNT THREAD-COUNT URL\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;CONNECTION-URL: connection address, e.g.&#39;amqp://127.0.0.1&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;AMQP-ADDRESS: AMQP node address, e.g. &#39;examples&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;MESSAGE-COUNT: number of messages to send\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;THREAD-COUNT: number of sender/receiver thread pairs\n&quot;</span>;</div><div class="line">            <span class="keywordflow">return</span> 1;</div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *url = argv[1];</div><div class="line">        <span class="keyword">con
 st</span> <span class="keywordtype">char</span> *address = argv[2];</div><div class="line">        <span class="keywordtype">int</span> n_messages = atoi(argv[3]);</div><div class="line">        <span class="keywordtype">int</span> n_threads = atoi(argv[4]);</div><div class="line">        <span class="keywordtype">int</span> count = n_messages * n_threads;</div><div class="line"></div><div class="line">        <span class="comment">// Total messages to be received, multiple receiver threads will decrement this.</span></div><div class="line">        std::atomic_int remaining;</div><div class="line">        remaining.store(count);</div><div class="line"></div><div class="line">        <span class="comment">// Run the proton container</span></div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a> container;</div><div class="line">        <span class="keyword">auto</span> container_thread = std::thread([&amp;]() { container.<a name="a22"
 ></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>(); });</div><div class="line"></div><div class="line">        <span class="comment">// A single sender and receiver to be shared by all the threads</span></div><div class="line">        sender send(container, url, address);</div><div class="line">        receiver recv(container, url, address);</div><div class="line"></div><div class="line">        <span class="comment">// Start receiver threads, then sender threads.</span></div><div class="line">        <span class="comment">// Starting receivers first gives all receivers a chance to compete for messages.</span></div><div class="line">        std::vector&lt;std::thread&gt; threads;</div><div class="line">        threads.reserve(n_threads*2); <span class="comment">// Avoid re-allocation once threads are started</span></div><div class="line">        <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt;
  n_threads; ++i)</div><div class="line">            threads.push_back(std::thread([&amp;]() { receive_thread(recv, remaining); }));</div><div class="line">        <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_threads; ++i)</div><div class="line">            threads.push_back(std::thread([&amp;]() { send_thread(send, n_messages); }));</div><div class="line"></div><div class="line">        <span class="comment">// Wait for threads to finish</span></div><div class="line">        <span class="keywordflow">for</span> (<span class="keyword">auto</span>&amp; t : threads) t.join();</div><div class="line">        send.close();</div><div class="line">        recv.close();</div><div class="line">        container_thread.join();</div><div class="line">        <span class="keywordflow">if</span> (remaining &gt; 0)</div><div class="line">            <span class="keywordflow">throw</span> std::runtime_error(<span class="stringliteral">&quot;not all mess
 ages were received&quot;</span>);</div><div class="line">        std::cout &lt;&lt; count &lt;&lt; <span class="stringliteral">&quot; messages sent and received&quot;</span> &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[08/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/encoder_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/encoder_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/encoder_8hpp_source.html
index 6cdac6a..7cc3555 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/encoder_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/encoder_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('encoder_8hpp_source.html','');});
 <div class="title">encoder.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="encoder_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CODEC_ENCODER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CODEC_ENCODER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contrib
 utor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&
 #160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the Licens
 e for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;../internal/data.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;../internal/type_traits.hpp&quot;</span></div><div class="line"><a name="l00
 027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;../types_fwd.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="common_8hpp.html">./common.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="
 keyword">class </span>scalar_base;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">namespace </span>internal{</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>value_base;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;}</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">namespace </span>codec {</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1encoder.html">   50</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1codec_1_1encod
 er.html">encoder</a> : <span class="keyword">public</span> internal::data {</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1encoder.html#a3c0a094e7f852de0a4197c0fdab85004">   53</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1encoder.html#a3c0a094e7f852de0a4197c0fdab85004">encoder</a>(<span class="keyword">const</span> data&amp; d) : data(d) {}</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>(internal::value_base&amp; v);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<
 /div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> encode(<span class="keywordtype">char</span>* buffer, <span class="keywordtype">size_t</span>&amp; size);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> encode(std::string&amp;);</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    PN_CPP_EXTERN std::string encode();</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>
 (<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint8_t);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int8_t);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint16_t);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int16_t);</div><div class="line"><a name="l00083"></a><span class="lineno"
 >   83</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint32_t);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int32_t);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">wchar_t</span>);</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint64_t);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href
 ="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int64_t);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">float</span>);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">double</span>);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN encoder&amp; <a 
 class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal32.html">decimal32</a>);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal64.html">decimal64</a>);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal128.html">decimal128</a>);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" hr
 ef="classproton_1_1uuid.html">uuid</a>&amp;);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1symbol.html">symbol</a>&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1binary.html">binary</a>&amp;);</div><div class="line"><a name="l00098"></a><span cl
 ass="lineno">   98</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1scalar__base.html">scalar_base</a>&amp;);</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> null&amp;);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> internal::value_base&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="l
 ine"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a>&amp;);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno
 ">  116</span>&#160;    <span class="comment">// Undefined template to  prevent pointers being implicitly converted to bool.</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keywordtype">void</span>* <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> T*);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>list_cref { T&amp; ref; list_cref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt
 ; <span class="keyword">struct </span>map_cref { T&amp; ref;  map_cref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>array_cref {</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> array_start;</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;        T&amp; ref;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;        array_cref(T&amp; r, <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> el, <span class="keywordtype">bool</span> described) : array_start(<a class="code" href="namesp
 aceproton.html#a83c2656d467d69eb49725c18f5aa13a9a1e029fbf0c881b85d80fc8e89b753688">ARRAY</a>, el, described), ref(r) {}</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;    };</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> list_cref&lt;T&gt; list(T&amp; x) { <span class="keywordflow">return</span> list_cref&lt;T&gt;(x); }</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> map_cref&lt;T&gt; <a class="code" href="classproton_1_1map.html">map</a>(T&amp; x) { <span class="keywordflow">return</span> map_cref&lt;T&gt;(x); }</div><div class="line"><a name="l00130"><
 /a><span class="lineno">  130</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> array_cref&lt;T&gt; array(T&amp; x, <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> element, <span class="keywordtype">bool</span> described=<span class="keyword">false</span>) {</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;        <span class="keywordflow">return</span> array_cref&lt;T&gt;(x, element, described);</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;    }</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; encoder&amp; operator&lt;&lt;(const map_cref&lt;T&gt;&amp; x) {</div><div class="line"><a nam
 e="l00135"></a><span class="lineno">  135</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;        *<span class="keyword">this</span> &lt;&lt; start::map();</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::const_iterator i = x.ref.begin(); i != x.ref.end(); ++i)</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;            *<span class="keyword">this</span> &lt;&lt; i-&gt;first &lt;&lt; i-&gt;second;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;      
   <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;    }</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; encoder&amp; operator&lt;&lt;(const list_cref&lt;T&gt;&amp; x) {</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;        *<span class="keyword">this</span> &lt;&lt; start::list();</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::const_iterator i = x.ref.begin(); i !=
  x.ref.end(); ++i)</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;            *<span class="keyword">this</span> &lt;&lt; *i;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;    }</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; encoder&amp; operator&lt;&lt;(const array_cref&lt;T&gt;&amp; x) {</div><div class="line"><a
  name="l00153"></a><span class="lineno">  153</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;        *<span class="keyword">this</span> &lt;&lt; x.array_start;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::const_iterator i = x.ref.begin(); i != x.ref.end(); ++i)</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;            *<span class="keyword">this</span> &lt;&lt; *i;</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;        <span class="keywordflow
 ">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;    }</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;    <span class="keyword">template</span>&lt;<span class="keyword">class</span> T, <span class="keyword">class</span> U&gt; encoder&amp; insert(<span class="keyword">const</span> T&amp; x, <span class="keywordtype">int</span> (*put)(pn_data_t*, U));</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    <span class="keywordtype">void</span> check(<span class="keywordtype">long</span> result);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;};</div><div class="line"><a name="l00166"></a><span cl
 ass="lineno">  166</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#acdb9db1193e2f3d0719ed56e4d7ae8d2">  168</a></span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp; e, <span class="keyword">const</span> <span class="keywordtype">char</span>* s) { <span class="keywordflow">return</span> e &lt;&lt; std::string(s); }</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">typename</span> internal::enable_if&lt;internal::is_unknown_integer&lt;T&gt;::v
 alue, <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp;&gt;::type</div><div class="line"><a name="l00172"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#aad3ea7f84bd70e8fef93486f56e4ee17">  172</a></span>&#160;<a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp; e, T i)  {</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;    <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;    <span class="keywordflow">return</span> e &lt;&lt; static_cast&lt;typename integer_type&lt;sizeof(T), is_signed&lt;T&gt;::value&gt;::type&gt;(i);</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;}</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;
 </div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;<span class="keyword">namespace </span>is_encodable_impl {   <span class="comment">// Protect the world from fallback operator&lt;&lt;</span></div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;<span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;sfinae::no <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a> <span class="keyword">const</span>&amp;, <span class="keyword">const</span> sfinae::any_t &amp;); <span class="comme
 nt">// Fallback</span></div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">typename</span> T&gt; <span class="keyword">struct </span>is_encodable : <span class="keyword">public</span> sfinae {</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;    <span class="keyword">static</span> yes test(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp;);</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;    <span class="keyword">static</span> no test(...);         <span class="comment">// Failed test, no match.</span></div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;    <span class="keyword">static</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>* e;</div><div class=
 "line"><a name="l00189"></a><span class="lineno">  189</span>&#160;    <span class="keyword">static</span> <span class="keyword">const</span> T* t;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;    <span class="keyword">static</span> <span class="keywordtype">bool</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a> = <span class="keyword">sizeof</span>(test(*e &lt;&lt; *t)) == <span class="keyword">sizeof</span>(yes);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;};</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;<span class="comment">// Avoid recursion</span></div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;<span class="keyword">template</span> &lt;&gt; <span class="keyword">struct </span>is_encodable&lt;value&
 gt; : <span class="keyword">public</span> true_type {};</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;} <span class="comment">// is_encodable_impl</span></div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;<span class="keyword">using</span> is_encodable_impl::is_encodable;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;<span class="comment">// Metafunction to test if a class looks like an encodable map from K to T.</span></div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> M, <span class="keyword">class</span> K, <span class="k
 eyword">class</span> T, <span class="keyword">class</span> Enable = <span class="keywordtype">void</span>&gt;</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;<span class="keyword">struct </span>is_encodable_map : <span class="keyword">public</span> internal::false_type {};</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> M, <span class="keyword">class</span> K, <span class="keyword">class</span> T&gt; <span class="keyword">struct </span>is_encodable_map&lt;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;    M, K, T, typename internal::enable_if&lt;</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;                 internal::is_same&lt;K, typename M::key_type&gt;::value &amp;&amp;</div><div
  class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;                 internal::is_same&lt;T, typename M::mapped_type&gt;::value &amp;&amp;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;                 is_encodable&lt;M&gt;::value</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;                 &gt;::type</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;    &gt; : <span class="keyword">public</span> internal::true_type {};</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;} <span class="comment">// codec</span></div><div class="line"><a name="l00216"></a><span class="lineno">  
 216</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;<span class="preprocessor">#endif </span></div><div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
+<a href="encoder_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CODEC_ENCODER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CODEC_ENCODER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contrib
 utor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&
 #160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the Licens
 e for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;../internal/data.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;../internal/type_traits.hpp&quot;</span></div><div class="line"><a name="l00
 027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;../types_fwd.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="common_8hpp.html">./common.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="
 keyword">class </span>scalar_base;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">namespace </span>internal{</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>value_base;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;}</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">namespace </span>codec {</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1encoder.html">   50</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1codec_1_1encod
 er.html">encoder</a> : <span class="keyword">public</span> internal::data {</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1encoder.html#a3c0a094e7f852de0a4197c0fdab85004">   53</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1encoder.html#a3c0a094e7f852de0a4197c0fdab85004">encoder</a>(<span class="keyword">const</span> data&amp; d) : data(d) {}</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>(internal::value_base&amp; v);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<
 /div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> encode(<span class="keywordtype">char</span>* buffer, <span class="keywordtype">size_t</span>&amp; size);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> encode(std::string&amp;);</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    PN_CPP_EXTERN std::string encode();</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>
 (<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint8_t);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int8_t);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint16_t);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int16_t);</div><div class="line"><a name="l00083"></a><span class="lineno"
 >   83</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint32_t);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int32_t);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">wchar_t</span>);</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(uint64_t);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href
 ="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(int64_t);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">float</span>);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keywordtype">double</span>);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN encoder&amp; <a 
 class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal32.html">decimal32</a>);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal64.html">decimal64</a>);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1decimal128.html">decimal128</a>);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" hr
 ef="classproton_1_1uuid.html">uuid</a>&amp;);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1symbol.html">symbol</a>&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1binary.html">binary</a>&amp;);</div><div class="line"><a name="l00098"></a><span cl
 ass="lineno">   98</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1scalar__base.html">scalar_base</a>&amp;);</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1null.html">null</a>&amp;);</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_NULLPTR</span></div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(decltype(<span class="keyword">nullptr</span>));</div><di
 v class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> internal::value_base&amp;);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a>&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div
 ><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;    PN_CPP_EXTERN encoder&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>&amp;);</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    <span class="comment">// Undefined template to  prevent pointers being implicitly converted to bool.</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keywordtype">void</span>* <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">
 operator&lt;&lt;</a>(<span class="keyword">const</span> T*);</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>list_cref { T&amp; ref; list_cref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>map_cref { T&amp; ref;  map_cref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>array_cref {</div><div class="lin
 e"><a name="l00126"></a><span class="lineno">  126</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> array_start;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;        T&amp; ref;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;        array_cref(T&amp; r, <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> el, <span class="keywordtype">bool</span> described) : array_start(<a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a1e029fbf0c881b85d80fc8e89b753688">ARRAY</a>, el, described), ref(r) {}</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    };</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;    <span class="keyword">template</span> 
 &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> list_cref&lt;T&gt; list(T&amp; x) { <span class="keywordflow">return</span> list_cref&lt;T&gt;(x); }</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> map_cref&lt;T&gt; <a class="code" href="classproton_1_1map.html">map</a>(T&amp; x) { <span class="keywordflow">return</span> map_cref&lt;T&gt;(x); }</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> array_cref&lt;T&gt; array(T&amp; x, <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> element, <span class="keywordtype">bool</span> described=<span class="keyword">false</span>) {</div><div class="line"><a name="l
 00134"></a><span class="lineno">  134</span>&#160;        <span class="keywordflow">return</span> array_cref&lt;T&gt;(x, element, described);</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;    }</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; encoder&amp; operator&lt;&lt;(const map_cref&lt;T&gt;&amp; x) {</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;        *<span class="keyword">this</span> &lt;&lt; start::map();</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;        <span class="keywordflow">for</span> (<span class="keyw
 ord">typename</span> T::const_iterator i = x.ref.begin(); i != x.ref.end(); ++i)</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;            *<span class="keyword">this</span> &lt;&lt; i-&gt;first &lt;&lt; i-&gt;second;</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;    }</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt
 ; encoder&amp; operator&lt;&lt;(const list_cref&lt;T&gt;&amp; x) {</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;        *<span class="keyword">this</span> &lt;&lt; start::list();</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::const_iterator i = x.ref.begin(); i != x.ref.end(); ++i)</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;            *<span class="keyword">this</span> &lt;&lt; *i;</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line">
 <a name="l00152"></a><span class="lineno">  152</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;    }</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; encoder&amp; operator&lt;&lt;(const array_cref&lt;T&gt;&amp; x) {</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;        internal::state_guard sg(*<span class="keyword">this</span>);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;        *<span class="keyword">this</span> &lt;&lt; x.array_start;</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;        <span class="keywordflow">for</span> (<span class=
 "keyword">typename</span> T::const_iterator i = x.ref.begin(); i != x.ref.end(); ++i)</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;            *<span class="keyword">this</span> &lt;&lt; *i;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;        *<span class="keyword">this</span> &lt;&lt; <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>();</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;    }</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00166"></a><span class="lineno">  166<
 /span>&#160;    <span class="keyword">template</span>&lt;<span class="keyword">class</span> T, <span class="keyword">class</span> U&gt; encoder&amp; insert(<span class="keyword">const</span> T&amp; x, <span class="keywordtype">int</span> (*put)(pn_data_t*, U));</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;    <span class="keywordtype">void</span> check(<span class="keywordtype">long</span> result);</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;};</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#acdb9db1193e2f3d0719ed56e4d7ae8d2">  171</a></span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<
 a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp; e, <span class="keyword">const</span> <span class="keywordtype">char</span>* s) { <span class="keywordflow">return</span> e &lt;&lt; std::string(s); }</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">typename</span> internal::enable_if&lt;internal::is_unknown_integer&lt;T&gt;::value, <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp;&gt;::type</div><div class="line"><a name="l00175"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#aad3ea7f84bd70e8fef93486f56e4ee17">  175</a></span>&#160;<a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1codec_1_1encoder
 .html">encoder</a>&amp; e, T i)  {</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;    <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;    <span class="keywordflow">return</span> e &lt;&lt; static_cast&lt;typename integer_type&lt;sizeof(T), is_signed&lt;T&gt;::value&gt;::type&gt;(i);</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;}</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;<span class="keyword">namespace </span>is_encodable_impl {   <span class="comment">// Protect the world from fallback operator&lt;&lt;</span></div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;</div><div class="line"><a
  name="l00184"></a><span class="lineno">  184</span>&#160;<span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;sfinae::no <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a> <span class="keyword">const</span>&amp;, <span class="keyword">const</span> sfinae::any_t &amp;); <span class="comment">// Fallback</span></div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">typename</span> T&gt; <span class="keyword">struct </span>is_encodable : <span class="keyword">public</span> sfinae {</div><div class="line"><a name="l00189"></a><spa
 n class="lineno">  189</span>&#160;    <span class="keyword">static</span> yes test(<a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>&amp;);</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;    <span class="keyword">static</span> no test(...);         <span class="comment">// Failed test, no match.</span></div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;    <span class="keyword">static</span> <a class="code" href="classproton_1_1codec_1_1encoder.html">encoder</a>* e;</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;    <span class="keyword">static</span> <span class="keyword">const</span> T* t;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;    <span class="keyword">static</span> <span class="keywordtype">bool</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a> = <span class="k
 eyword">sizeof</span>(test(*e &lt;&lt; *t)) == <span class="keyword">sizeof</span>(yes);</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;};</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;<span class="comment">// Avoid recursion</span></div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;<span class="keyword">template</span> &lt;&gt; <span class="keyword">struct </span>is_encodable&lt;value&gt; : <span class="keyword">public</span> true_type {};</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;} <span class="comment">// is_encodable_impl</span></div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lin
 eno">  201</span>&#160;<span class="keyword">using</span> is_encodable_impl::is_encodable;</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;<span class="comment">// Metafunction to test if a class looks like an encodable map from K to T.</span></div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> M, <span class="keyword">class</span> K, <span class="keyword">class</span> T, <span class="keyword">class</span> Enable = <span class="keywordtype">void</span>&gt;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;<span class="keyword">struct </span>is_encodable_map : <span class="keyword">public</span> internal::false_type {};</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="line"><a 
 name="l00207"></a><span class="lineno">  207</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> M, <span class="keyword">class</span> K, <span class="keyword">class</span> T&gt; <span class="keyword">struct </span>is_encodable_map&lt;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;    M, K, T, typename internal::enable_if&lt;</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;                 internal::is_same&lt;K, typename M::key_type&gt;::value &amp;&amp;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;                 internal::is_same&lt;T, typename M::mapped_type&gt;::value &amp;&amp;</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;                 is_encodable&lt;M&gt;::value</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;                 &gt;::type</div><div class="l
 ine"><a name="l00213"></a><span class="lineno">  213</span>&#160;    &gt; : <span class="keyword">public</span> internal::true_type {};</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;} <span class="comment">// codec</span></div><div class="line"><a name="l00219"></a><span class="lineno">  219</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00220"></a><span class="lineno">  220</span>&#160;</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;<span class="preprocessor">#endif </span></div><div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a href="namespaceproton.html#ae6fabe30961a3d3280bb
 8445e743b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
 <div class="ttc" id="namespaceproton_1_1codec_html_structproton_1_1codec_1_1start"><div class="ttname"><a href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">proton::codec::start</a></div><div class="ttdoc">Unsettled API - Start encoding a complex type. </div><div class="ttdef"><b>Definition:</b> common.hpp:34</div></div>
 <div class="ttc" id="classproton_1_1codec_1_1encoder_html"><div class="ttname"><a href="classproton_1_1codec_1_1encoder.html">proton::codec::encoder</a></div><div class="ttdoc">Unsettled API - A stream-like encoder from C++ values to AMQP bytes. </div><div class="ttdef"><b>Definition:</b> encoder.hpp:50</div></div>
 <div class="ttc" id="namespaceproton_html_a83c2656d467d69eb49725c18f5aa13a9a1e029fbf0c881b85d80fc8e89b753688"><div class="ttname"><a href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a1e029fbf0c881b85d80fc8e89b753688">proton::ARRAY</a></div><div class="ttdoc">A sequence of values of the same type. </div><div class="ttdef"><b>Definition:</b> type_id.hpp:60</div></div>
@@ -112,6 +112,7 @@ $(document).ready(function(){initNavTree('encoder_8hpp_source.html','');});
 <div class="ttc" id="classproton_1_1value_html"><div class="ttname"><a href="classproton_1_1value.html">proton::value</a></div><div class="ttdoc">A holder for any AMQP value, simple or complex. </div><div class="ttdef"><b>Definition:</b> value.hpp:57</div></div>
 <div class="ttc" id="namespaceproton_1_1codec_html_structproton_1_1codec_1_1finish"><div class="ttname"><a href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">proton::codec::finish</a></div><div class="ttdoc">Unsettled API - Finish inserting or extracting a complex type. </div><div class="ttdef"><b>Definition:</b> common.hpp:57</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
+<div class="ttc" id="classproton_1_1null_html"><div class="ttname"><a href="classproton_1_1null.html">proton::null</a></div><div class="ttdoc">The type of the AMQP null value. </div><div class="ttdef"><b>Definition:</b> null.hpp:38</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->


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


[26/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/send_8c-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/send_8c-example.html b/content/releases/qpid-proton-master/proton/c/api/send_8c-example.html
index dcafbcd..a15bd1c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/send_8c-example.html
+++ b/content/releases/qpid-proton-master/proton/c/api/send_8c-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('send_8c-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>Send a fixed number of messages to the "examples" node.Can be used with <a class="el" href="broker_8c-example.html">broker.c</a>, <a class="el" href="direct_8c-example.html">direct.c</a> or an external AMQP broker.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8h.html">proton/connection.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8h.html">proton/delivery.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8h.html">proton/message.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="proactor_8h.html">proton/proactor.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="session_8h.html">proton/session.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;
 </span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;stdio.h&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;stdlib.h&gt;</span></div><div class="line"></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>app_data_t {</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *host, *port;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *amqp_address;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *container_id;</div><div class="line">  <span class="keywordtype">int</span> message_count;</div><div class="line"></div><div class="line">  <a class="code" href="types_8h.html#abba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor;</div><div class="line">  <a name="_a0"></a><a class="code" href="group__api__types.html#structpn__rwbyt
 es__t">pn_rwbytes_t</a> message_buffer;</div><div class="line">  <span class="keywordtype">int</span> sent;</div><div class="line">  <span class="keywordtype">int</span> acknowledged;</div><div class="line">} app_data_t;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">int</span> exit_code = 0;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> check_condition(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *cond) {</div><div class="line">  <span class="keywordflow">if</span> (<a name="a1"></a><a class="code" href="group__condition.html#ga112611a7a4087e050c476a430db2cfb9">pn_condition_is_set</a>(cond)) {</div><div class="line">    fprintf(stderr, <span class="stringliteral">&quot;%s: %s: %s\n&quot;</span>, <a na
 me="a2"></a><a class="code" href="group__event.html#ga3a85c046c11ce692c23b9566b022d54b">pn_event_type_name</a>(<a name="a3"></a><a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(e)),</div><div class="line">            <a name="a4"></a><a class="code" href="group__condition.html#ga05b0d374d90f11d9ebbf818662569689">pn_condition_get_name</a>(cond), <a name="a5"></a><a class="code" href="group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8">pn_condition_get_description</a>(cond));</div><div class="line">    <a name="a6"></a><a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a name="a7"></a><a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e));</div><div class="line">    exit_code = 1;</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Create a message with a map { 
 &quot;sequence&quot; : number } encode it and return the encoded buffer. */</span></div><div class="line"><span class="keyword">static</span> <a name="_a8"></a><a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> encode_message(app_data_t* app) {</div><div class="line">  <span class="comment">/* Construct a message with the map { &quot;sequence&quot;: app.sent } */</span></div><div class="line">  <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a>* message = <a name="a9"></a><a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>();</div><div class="line">  <a name="a10"></a><a class="code" href="group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016">pn_data_put_int</a>(<a name="a11"></a><a class="code" href="group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de">pn_message_id</a>(message), app-&gt;sent); <span class="comment">/* Set the message_id also */</span></div><div class
 ="line">  <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a>* body = <a name="a12"></a><a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(message);</div><div class="line">  <a name="a13"></a><a class="code" href="group__data.html#ga4c77c7a884bbd9a757b31060962d8543">pn_data_put_map</a>(body);</div><div class="line">  <a name="a14"></a><a class="code" href="group__data.html#ga1093449b80357dabf3f70a4bf804f4f7">pn_data_enter</a>(body);</div><div class="line">  <a name="a15"></a><a class="code" href="group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee">pn_data_put_string</a>(body, <a name="a16"></a><a class="code" href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(<span class="keyword">sizeof</span>(<span class="stringliteral">&quot;sequence&quot;</span>)-1, <span class="stringliteral">&quot;sequence&quot;</span>));</div><div class="line">  <a class="code" href="group__data.htm
 l#ga6cfb9e64b87f8d90a5b4237ca016a016">pn_data_put_int</a>(body, app-&gt;sent); <span class="comment">/* The sequence number */</span></div><div class="line">  <a name="a17"></a><a class="code" href="group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48">pn_data_exit</a>(body);</div><div class="line"></div><div class="line">  <span class="comment">/* encode the message, expanding the encode buffer as needed */</span></div><div class="line">  <span class="keywordflow">if</span> (app-&gt;message_buffer.start == NULL) {</div><div class="line">    <span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">size_t</span> initial_size = 128;</div><div class="line">    app-&gt;message_buffer = <a name="a18"></a><a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(initial_size, (<span class="keywordtype">char</span>*)malloc(initial_size));</div><div class="line">  }</div><div class="line">  <span class="comment">/*
  app-&gt;message_buffer is the total buffer space available. */</span></div><div class="line">  <span class="comment">/* mbuf wil point at just the portion used by the encoded message */</span></div><div class="line">  <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> mbuf = <a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(app-&gt;message_buffer.size, app-&gt;message_buffer.start);</div><div class="line">  <span class="keywordtype">int</span> status = 0;</div><div class="line">  <span class="keywordflow">while</span> ((status = <a name="a19"></a><a class="code" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a>(message, mbuf.<a name="a20"></a>start, &amp;mbuf.<a name="a21"></a>size)) == <a name="a22"></a><a class="code" href="group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7">PN_OVERFLOW</a>) {</div><div class="line">    app-&gt;message_buffer.size *= 2;</div><div cla
 ss="line">    app-&gt;message_buffer.start = (<span class="keywordtype">char</span>*)realloc(app-&gt;message_buffer.start, app-&gt;message_buffer.size);</div><div class="line">    mbuf.size = app-&gt;message_buffer.size;</div><div class="line">  }</div><div class="line">  <span class="keywordflow">if</span> (status != 0) {</div><div class="line">    fprintf(stderr, <span class="stringliteral">&quot;error encoding message: %s\n&quot;</span>, <a name="a23"></a><a class="code" href="group__error.html#ga67cbe6ebb143370e0604f5b84d716c56">pn_error_text</a>(<a name="a24"></a><a class="code" href="group__message.html#ga9ad09178e7682efde76e2d39f352dfe8">pn_message_error</a>(message)));</div><div class="line">    exit(1);</div><div class="line">  }</div><div class="line">  <a name="a25"></a><a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(message);</div><div class="line">  <span class="keywordflow">return</span> <a class="code" href="group__api
 __types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(mbuf.size, mbuf.start);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Returns true to continue, false if finished */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">bool</span> handle(app_data_t* app, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* event) {</div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(event)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a26"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e">PN_CONNECTION_INIT</a>: {</div><div class="line">     <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</
 a>* c = <a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event);</div><div class="line">     <a name="a27"></a><a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(c, app-&gt;container_id);</div><div class="line">     <a name="a28"></a><a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(c);</div><div class="line">     <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a>* s = <a name="a29"></a><a class="code" href="group__session.html#ga1feff407b8fe308a14f283d193246f3c">pn_session</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">     <a name="a30"></a><a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(s);</div><div class="line">     <a class="code" hr
 ef="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>* l = <a name="a31"></a><a class="code" href="group__link.html#ga469bef2e81c53e85899ffbb277616a8c">pn_sender</a>(s, <span class="stringliteral">&quot;my_sender&quot;</span>);</div><div class="line">     <a name="a32"></a><a class="code" href="group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1">pn_terminus_set_address</a>(<a name="a33"></a><a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a>(l), app-&gt;amqp_address);</div><div class="line">     <a name="a34"></a><a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(l);</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a35"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f">PN_LIN
 K_FLOW</a>: {</div><div class="line">     <span class="comment">/* The peer has given us some credit, now we can send messages */</span></div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender = <a name="a36"></a><a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event);</div><div class="line">     <span class="keywordflow">while</span> (<a name="a37"></a><a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(sender) &gt; 0 &amp;&amp; app-&gt;sent &lt; app-&gt;message_count) {</div><div class="line">       ++app-&gt;sent;</div><div class="line">       <span class="comment">// Use sent counter as unique delivery tag.</span></div><div class="line">       <a name="a38"></a><a class="code" href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a>(sender, <a name="a39"></a><a class="code" href="group__delivery.html#gae
 a4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a>((<span class="keyword">const</span> <span class="keywordtype">char</span> *)&amp;app-&gt;sent, <span class="keyword">sizeof</span>(app-&gt;sent)));</div><div class="line">       <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> msgbuf = encode_message(app);</div><div class="line">       <a name="a40"></a><a class="code" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9">pn_link_send</a>(sender, msgbuf.<a name="a41"></a>start, msgbuf.<a name="a42"></a>size);</div><div class="line">       <a name="a43"></a><a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(sender);</div><div class="line">     }</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a44"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b9984
 2103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a>: {</div><div class="line">     <span class="comment">/* We received acknowledgedment from the peer that a message was delivered. */</span></div><div class="line">     <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a>* d = <a name="a45"></a><a class="code" href="group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a>(event);</div><div class="line">     <span class="keywordflow">if</span> (<a name="a46"></a><a class="code" href="group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a>(d) == <a name="a47"></a><a class="code" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">PN_ACCEPTED</a>) {</div><div class="line">       <span class="keywordflow">if</span> (++app-&gt;acknowledged == app-&gt;message_count) {</div><div class="line">         printf(<span class="stringliteral">&quot;%d messages sent and acknowledged\n&quot;<
 /span>, app-&gt;acknowledged);</div><div class="line">         <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">         <span class="comment">/* Continue handling events till we receive TRANSPORT_CLOSED */</span></div><div class="line">       }</div><div class="line">     } <span class="keywordflow">else</span> {</div><div class="line">       fprintf(stderr, <span class="stringliteral">&quot;unexpected delivery state %d\n&quot;</span>, (<span class="keywordtype">int</span>)<a class="code" href="group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a>(d));</div><div class="line">       <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_eve
 nt_connection</a>(event));</div><div class="line">       exit_code=1;</div><div class="line">     }</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a48"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a>:</div><div class="line">    check_condition(event, <a name="a49"></a><a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a>(<a name="a50"></a><a class="code" href="group__event.html#ga14525ae84870388141898bbf57f2b151">pn_event_transport</a>(event)));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a51"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf
 9f03d214c9b4fea5cf11b2f">PN_CONNECTION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a52"></a><a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a53"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135">PN_SESSION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a54"></a><a class="code" href="gro
 up__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a>(<a name="a55"></a><a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a56"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f">PN_LINK_REMOTE_CLOSE</a>:</div><div class="line">   <span class="keywordflow">case</span> <a name="a57"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2">PN_LINK_REMOTE_DETACH</a>:</div><div class="l
 ine">    check_condition(event, <a name="a58"></a><a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a59"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a>:</div><div class="line">    <span class="keywordflow">return</span> <span class="keyword">false</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</s
 pan>: <span class="keywordflow">break</span>;</div><div class="line">  }</div><div class="line">  <span class="keywordflow">return</span> <span class="keyword">true</span>;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> run(app_data_t *app) {</div><div class="line">  <span class="comment">/* Loop and handle events */</span></div><div class="line">  <span class="keywordflow">do</span> {</div><div class="line">    <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events = <a name="a60"></a><a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(app-&gt;proactor);</div><div class="line">    <span class="keywordflow">for</span> (<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e = <a name="a61"></a><a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next
 </a>(events); e; e = <a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a>(events)) {</div><div class="line">      <span class="keywordflow">if</span> (!handle(app, e)) {</div><div class="line">        <span class="keywordflow">return</span>;</div><div class="line">      }</div><div class="line">    }</div><div class="line">    <a name="a62"></a><a class="code" href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a>(app-&gt;proactor, events);</div><div class="line">  } <span class="keywordflow">while</span>(<span class="keyword">true</span>);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">  <span class="keyword">struct </span>app_data_t app = {0};</div><div class="line">  <span class="keywordtype">int</span> i = 0;</div><div class="
 line">  app.container_id = argv[i++];   <span class="comment">/* Should be unique */</span></div><div class="line">  app.host = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;&quot;</span>;</div><div class="line">  app.port = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;amqp&quot;</span>;</div><div class="line">  app.amqp_address = (argc &gt; i) ? argv[i++] : <span class="stringliteral">&quot;examples&quot;</span>;</div><div class="line">  app.message_count = (argc &gt; i) ? atoi(argv[i++]) : 10;</div><div class="line"></div><div class="line">  app.proactor = <a name="a63"></a><a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>();</div><div class="line">  <span class="keywordtype">char</span> addr[<a name="a64"></a><a class="code" href="group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256">PN_MAX_ADDR</a>];</div><div class="line">  <a name="a65"></a><a class="code" href="group__proactor.html#gaf67a7642c900
 3b36255b58776b494c96">pn_proactor_addr</a>(addr, <span class="keyword">sizeof</span>(addr), app.host, app.port);</div><div class="line">  <a name="a66"></a><a class="code" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a>(app.proactor, <a name="a67"></a><a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>(), addr);</div><div class="line">  run(&amp;app);</div><div class="line">  <a name="a68"></a><a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(app.proactor);</div><div class="line">  free(app.message_buffer.start);</div><div class="line">  <span class="keywordflow">return</span> exit_code;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/session_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/session_8h.html b/content/releases/qpid-proton-master/proton/c/api/session_8h.html
index 876c4e9..0484234 100755
--- a/content/releases/qpid-proton-master/proton/c/api/session_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/session_8h.html
@@ -117,8 +117,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga0f95b5177494a68991d75444c2f6f812"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a session object.  <a href="group__session.html#ga0f95b5177494a68991d75444c2f6f812">More...</a><br /></td></tr>
 <tr class="separator:ga0f95b5177494a68991d75444c2f6f812"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
+<tr class="memdesc:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>.  <a href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">More...</a><br /></td></tr>
 <tr class="separator:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga31f2e4cc76135f79e96453aa72d441b2"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, void *context)</td></tr>
+<tr class="memdesc:ga31f2e4cc76135f79e96453aa72d441b2"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>.  <a href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">More...</a><br /></td></tr>
 <tr class="separator:ga31f2e4cc76135f79e96453aa72d441b2"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga0128a4413f413569b91e2bc78217728a"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a">pn_session_attachments</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
 <tr class="memdesc:ga0128a4413f413569b91e2bc78217728a"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a session object.  <a href="group__session.html#ga0128a4413f413569b91e2bc78217728a">More...</a><br /></td></tr>
@@ -127,6 +129,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga7e2a4567e3488a225257e4d883a7e78f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the endpoint state flags for a session.  <a href="group__session.html#ga7e2a4567e3488a225257e4d883a7e78f">More...</a><br /></td></tr>
 <tr class="separator:ga7e2a4567e3488a225257e4d883a7e78f"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
+<tr class="memdesc:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">More...</a><br /></td></tr>
 <tr class="separator:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gafdb7b3d530adaaf30aecc73ca6319cf3"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">pn_session_condition</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
 <tr class="memdesc:gafdb7b3d530adaaf30aecc73ca6319cf3"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local condition associated with the session endpoint.  <a href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">More...</a><br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/session_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/session_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/session_8h_source.html
index 725a378..840b946 100755
--- a/content/releases/qpid-proton-master/proton/c/api/session_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/session_8h_source.html
@@ -93,16 +93,16 @@ $(document).ready(function(){initNavTree('session_8h_source.html','');});
 <div class="title">session.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="session_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SESSION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SESSION_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agr
 eements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class
 ="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span>
 </div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno"
 >   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocess
 or">#ifdef __cplusplus</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga1feff407b8fe308a14f283d193246f3c">pn_session</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PN_EXTERN <span class="ke
 ywordtype">void</span> <a class="code" href="group__session.html#ga0f95b5177494a68991d75444c2f6f812">pn_session_free</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a>(<a class="code" href="g
 roup__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__session.html#ga0128a4413f413569b91e2bc78217728a">pn_session_attachments</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__session.html#ga7e2a4567e3488a225257e4d883a7e78f">pn_session_state</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a
 > *session);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">pn_session_condition</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><
 a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00174"
 ></a><span class="lineno">  174</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;PN_EXTERN <span class="keyword
 type">size_t</span> <a class="code" href="group__session.html#ga1fdeb3d6606e869790a228d847136cb0">pn_session_get_incoming_capacity</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9">pn_session_set_incoming_capacity</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">size_t</span> capacity);</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#ga931b89bd7
 37ab293056cb695dddd9800">pn_session_get_outgoing_window</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#gaca5962e539688b4f31b5b91136aa3c79">pn_session_set_outgoing_window</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">size_t</span> window);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#gabcae388cdcb33e976b490525ec600b50">pn_session_outgoing_bytes</a>(<a class="code" href="gr
 oup__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#ga55a8429e178831556844ab251ef67c77">pn_session_incoming_bytes</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga577d6f6659958c5d89cd56e944fbd999">pn_session_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection,
  <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga238754f924f84597056f3249a7e7a35f">pn_session_next</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;}</div><d
 iv class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00296"></a><span class="lineno">  296</span>&#160;</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* session.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
-<div class="ttc" id="group__session_html_ga1685531ca6fb6fb1058d5455a3c3edde"><div class="ttname"><a href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a></div><div class="ttdeci">pn_error_t * pn_session_error(pn_session_t *session)</div></div>
+<a href="session_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SESSION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SESSION_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agr
 eements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class
 ="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span>
 </div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno"
 >   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocess
 or">#ifdef __cplusplus</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga1feff407b8fe308a14f283d193246f3c">pn_session</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PN_EXTERN <span class="ke
 ywordtype">void</span> <a class="code" href="group__session.html#ga0f95b5177494a68991d75444c2f6f812">pn_session_free</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a>(<a class="code" href="g
 roup__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__session.html#ga0128a4413f413569b91e2bc78217728a">pn_session_attachments</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__session.html#ga7e2a4567e3488a225257e4d883a7e78f">pn_session_state</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a
 > *session);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">pn_session_condition</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><
 a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00174"
 ></a><span class="lineno">  174</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;PN_EXTERN <span class="keyword
 type">size_t</span> <a class="code" href="group__session.html#ga1fdeb3d6606e869790a228d847136cb0">pn_session_get_incoming_capacity</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9">pn_session_set_incoming_capacity</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">size_t</span> capacity);</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#ga931b89bd7
 37ab293056cb695dddd9800">pn_session_get_outgoing_window</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;</div><div class="line"><a name="l00241"></a><span class="lineno">  241</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__session.html#gaca5962e539688b4f31b5b91136aa3c79">pn_session_set_outgoing_window</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keywordtype">size_t</span> window);</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#gabcae388cdcb33e976b490525ec600b50">pn_session_outgoing_bytes</a>(<a class="code" href="gr
 oup__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__session.html#ga55a8429e178831556844ab251ef67c77">pn_session_incoming_bytes</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session);</div><div class="line"><a name="l00258"></a><span class="lineno">  258</span>&#160;</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga577d6f6659958c5d89cd56e944fbd999">pn_session_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection,
  <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__session.html#ga238754f924f84597056f3249a7e7a35f">pn_session_next</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;}</div><d
 iv class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00300"></a><span class="lineno">  300</span>&#160;</div><div class="line"><a name="l00301"></a><span class="lineno">  301</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* session.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<div class="ttc" id="group__session_html_ga1685531ca6fb6fb1058d5455a3c3edde"><div class="ttname"><a href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a></div><div class="ttdeci">pn_error_t * pn_session_error(pn_session_t *session)</div><div class="ttdoc">Deprecated </div></div>
 <div class="ttc" id="group__session_html_gaedc306d86e778cbf8eaaf528c3eacae9"><div class="ttname"><a href="group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9">pn_session_set_incoming_capacity</a></div><div class="ttdeci">void pn_session_set_incoming_capacity(pn_session_t *session, size_t capacity)</div><div class="ttdoc">Set the incoming capacity for a session object. </div></div>
 <div class="ttc" id="group__session_html_ga0f95b5177494a68991d75444c2f6f812"><div class="ttname"><a href="group__session.html#ga0f95b5177494a68991d75444c2f6f812">pn_session_free</a></div><div class="ttdeci">void pn_session_free(pn_session_t *session)</div><div class="ttdoc">Free a session object. </div></div>
 <div class="ttc" id="group__session_html_gabcae388cdcb33e976b490525ec600b50"><div class="ttname"><a href="group__session.html#gabcae388cdcb33e976b490525ec600b50">pn_session_outgoing_bytes</a></div><div class="ttdeci">size_t pn_session_outgoing_bytes(pn_session_t *session)</div><div class="ttdoc">Get the number of outgoing bytes currently buffered by a session. </div></div>
 <div class="ttc" id="group__session_html_gae21b3fda1567bad1f8a8fe162ffaeece"><div class="ttname"><a href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a></div><div class="ttdeci">pn_condition_t * pn_session_remote_condition(pn_session_t *session)</div><div class="ttdoc">Get the remote condition associated with the session endpoint. </div></div>
 <div class="ttc" id="group__session_html_gaca5962e539688b4f31b5b91136aa3c79"><div class="ttname"><a href="group__session.html#gaca5962e539688b4f31b5b91136aa3c79">pn_session_set_outgoing_window</a></div><div class="ttdeci">void pn_session_set_outgoing_window(pn_session_t *session, size_t window)</div><div class="ttdoc">Set the outgoing window for a session object. </div></div>
-<div class="ttc" id="group__session_html_ga07da6cda67bdb37511b0aa9c8a04d532"><div class="ttname"><a href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a></div><div class="ttdeci">void * pn_session_get_context(pn_session_t *session)</div></div>
+<div class="ttc" id="group__session_html_ga07da6cda67bdb37511b0aa9c8a04d532"><div class="ttname"><a href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a></div><div class="ttdeci">void * pn_session_get_context(pn_session_t *session)</div><div class="ttdoc">Deprecated - Use pn_session_attachments(). </div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
-<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:294</div></div>
+<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:292</div></div>
 <div class="ttc" id="error_8h_html"><div class="ttname"><a href="error_8h.html">error.h</a></div><div class="ttdoc">A Proton API error. </div></div>
 <div class="ttc" id="group__session_html_gaa45a8aa758334528a86cb7914ebe8545"><div class="ttname"><a href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a></div><div class="ttdeci">pn_connection_t * pn_session_connection(pn_session_t *session)</div><div class="ttdoc">Get the parent connection for a session object. </div></div>
 <div class="ttc" id="group__session_html_ga0128a4413f413569b91e2bc78217728a"><div class="ttname"><a href="group__session.html#ga0128a4413f413569b91e2bc78217728a">pn_session_attachments</a></div><div class="ttdeci">pn_record_t * pn_session_attachments(pn_session_t *session)</div><div class="ttdoc">Get the attachments that are associated with a session object. </div></div>
@@ -111,14 +111,14 @@ $(document).ready(function(){initNavTree('session_8h_source.html','');});
 <div class="ttc" id="group__session_html_ga931b89bd737ab293056cb695dddd9800"><div class="ttname"><a href="group__session.html#ga931b89bd737ab293056cb695dddd9800">pn_session_get_outgoing_window</a></div><div class="ttdeci">size_t pn_session_get_outgoing_window(pn_session_t *session)</div><div class="ttdoc">Get the outgoing window for a session object. </div></div>
 <div class="ttc" id="group__session_html_ga7e2a4567e3488a225257e4d883a7e78f"><div class="ttname"><a href="group__session.html#ga7e2a4567e3488a225257e4d883a7e78f">pn_session_state</a></div><div class="ttdeci">pn_state_t pn_session_state(pn_session_t *session)</div><div class="ttdoc">Get the endpoint state flags for a session. </div></div>
 <div class="ttc" id="group__session_html_ga577d6f6659958c5d89cd56e944fbd999"><div class="ttname"><a href="group__session.html#ga577d6f6659958c5d89cd56e944fbd999">pn_session_head</a></div><div class="ttdeci">pn_session_t * pn_session_head(pn_connection_t *connection, pn_state_t state)</div><div class="ttdoc">Retrieve the first session from a given connection that matches the specified state mask...</div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__session_html_ga1fdeb3d6606e869790a228d847136cb0"><div class="ttname"><a href="group__session.html#ga1fdeb3d6606e869790a228d847136cb0">pn_session_get_incoming_capacity</a></div><div class="ttdeci">size_t pn_session_get_incoming_capacity(pn_session_t *session)</div><div class="ttdoc">Get the incoming capacity of the session measured in bytes. </div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
 <div class="ttc" id="group__session_html_ga2b345eada2c15249caaefaa894d1aae3"><div class="ttname"><a href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a></div><div class="ttdeci">void pn_session_open(pn_session_t *session)</div><div class="ttdoc">Open a session. </div></div>
 <div class="ttc" id="group__session_html_ga12e5c4e71b0df4087d16ccc8b63b42b5"><div class="ttname"><a href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a></div><div class="ttdeci">void pn_session_close(pn_session_t *session)</div><div class="ttdoc">Close a session. </div></div>
-<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:269</div></div>
+<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:267</div></div>
 <div class="ttc" id="group__session_html_ga1feff407b8fe308a14f283d193246f3c"><div class="ttname"><a href="group__session.html#ga1feff407b8fe308a14f283d193246f3c">pn_session</a></div><div class="ttdeci">pn_session_t * pn_session(pn_connection_t *connection)</div><div class="ttdoc">Factory for creating a new session on a given connection object. </div></div>
-<div class="ttc" id="group__session_html_ga31f2e4cc76135f79e96453aa72d441b2"><div class="ttname"><a href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a></div><div class="ttdeci">void pn_session_set_context(pn_session_t *session, void *context)</div></div>
+<div class="ttc" id="group__session_html_ga31f2e4cc76135f79e96453aa72d441b2"><div class="ttname"><a href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a></div><div class="ttdeci">void pn_session_set_context(pn_session_t *session, void *context)</div><div class="ttdoc">Deprecated - Use pn_session_attachments(). </div></div>
 <div class="ttc" id="group__session_html_ga238754f924f84597056f3249a7e7a35f"><div class="ttname"><a href="group__session.html#ga238754f924f84597056f3249a7e7a35f">pn_session_next</a></div><div class="ttdeci">pn_session_t * pn_session_next(pn_session_t *session, pn_state_t state)</div><div class="ttdoc">Retrieve the next session from a given connection that matches the specified state mask...</div></div>
 <div class="ttc" id="group__session_html_gafdb7b3d530adaaf30aecc73ca6319cf3"><div class="ttname"><a href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">pn_session_condition</a></div><div class="ttdeci">pn_condition_t * pn_session_condition(pn_session_t *session)</div><div class="ttdoc">Get the local condition associated with the session endpoint. </div></div>
 </div><!-- fragment --></div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/ssl_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/ssl_8h.html b/content/releases/qpid-proton-master/proton/c/api/ssl_8h.html
index f8b6ed8..d77345d 100755
--- a/content/releases/qpid-proton-master/proton/c/api/ssl_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/ssl_8h.html
@@ -174,6 +174,12 @@ Functions</h2></td></tr>
 <tr class="memitem:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">pn_ssl_domain_set_peer_authentication</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const <a class="el" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode, const char *trusted_CAs)</td></tr>
 <tr class="memdesc:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the level of verification used on the peer certificate.  <a href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">More...</a><br /></td></tr>
 <tr class="separator:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga333fcb941ed20421373f37b23d84fc98"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">pn_ssl_domain_set_protocols</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const char *protocols)</td></tr>
+<tr class="memdesc:ga333fcb941ed20421373f37b23d84fc98"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the list of permitted TLS protocols.  <a href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">More...</a><br /></td></tr>
+<tr class="separator:ga333fcb941ed20421373f37b23d84fc98"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">pn_ssl_domain_set_ciphers</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const char *ciphers)</td></tr>
+<tr class="memdesc:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the list of permitted ciphers.  <a href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">More...</a><br /></td></tr>
+<tr class="separator:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2ac989a62dcd138be770fae0bbb85e74"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">pn_ssl_domain_allow_unsecured_client</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain)</td></tr>
 <tr class="memdesc:ga2ac989a62dcd138be770fae0bbb85e74"><td class="mdescLeft">&#160;</td><td class="mdescRight">Permit a server to accept connection requests from non-SSL clients.  <a href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">More...</a><br /></td></tr>
 <tr class="separator:ga2ac989a62dcd138be770fae0bbb85e74"><td class="memSeparator" colspan="2">&#160;</td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/ssl_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/ssl_8h.js b/content/releases/qpid-proton-master/proton/c/api/ssl_8h.js
index b7690fc..7f9b6fe 100755
--- a/content/releases/qpid-proton-master/proton/c/api/ssl_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/ssl_8h.js
@@ -37,6 +37,8 @@ var ssl_8h =
     [ "pn_ssl_domain_set_credentials", "group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa", null ],
     [ "pn_ssl_domain_set_trusted_ca_db", "group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d", null ],
     [ "pn_ssl_domain_set_peer_authentication", "group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11", null ],
+    [ "pn_ssl_domain_set_protocols", "group__ssl.html#ga333fcb941ed20421373f37b23d84fc98", null ],
+    [ "pn_ssl_domain_set_ciphers", "group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc", null ],
     [ "pn_ssl_domain_allow_unsecured_client", "group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74", null ],
     [ "pn_ssl", "group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c", null ],
     [ "pn_ssl_init", "group__ssl.html#ga45f319dd31ad456b8a85927888f94acf", null ],


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


[51/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
QPID-8154: Refresh the proton doc snapshot


Project: http://git-wip-us.apache.org/repos/asf/qpid-site/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-site/commit/701caf21
Tree: http://git-wip-us.apache.org/repos/asf/qpid-site/tree/701caf21
Diff: http://git-wip-us.apache.org/repos/asf/qpid-site/diff/701caf21

Branch: refs/heads/asf-site
Commit: 701caf213c5b8258b8de5ed6b423449a9147b2a5
Parents: ed9aabf
Author: Justin Ross <jr...@apache.org>
Authored: Tue May 1 06:42:59 2018 -0700
Committer: Justin Ross <jr...@apache.org>
Committed: Tue May 1 06:43:14 2018 -0700

----------------------------------------------------------------------
 content/releases/qpid-proton-master/index.html  |     6 +-
 .../proton/c/api/annotated.html                 |     2 +-
 .../proton/c/api/broker_8c-example.html         |     2 +-
 .../proton/c/api/cid_8h_source.html             |    10 +-
 .../proton/c/api/codec_8h.html                  |     6 +-
 .../proton/c/api/codec_8h_source.html           |    18 +-
 .../proton/c/api/connection_8h.html             |     7 +-
 .../proton/c/api/connection_8h_source.html      |    18 +-
 .../proton/c/api/connection__driver_8h.html     |    23 +-
 .../proton/c/api/connection__driver_8h.js       |     3 +-
 .../c/api/connection__driver_8h_source.html     |    23 +-
 .../proton/c/api/delivery_8h.html               |     6 +-
 .../proton/c/api/delivery_8h_source.html        |    18 +-
 .../proton/c/api/deprecated.html                |    50 +-
 .../api/dir_25143d27009f52d175c1d192441a738a.js |    10 +
 .../proton/c/api/direct_8c-example.html         |     2 +-
 .../proton/c/api/engine_8h_source.html          |    10 +-
 .../proton/c/api/error_8h.html                  |     6 +-
 .../qpid-proton-master/proton/c/api/error_8h.js |     1 +
 .../proton/c/api/error_8h_source.html           |     2 +-
 .../proton/c/api/event_8h_source.html           |    16 +-
 .../qpid-proton-master/proton/c/api/files.html  |    52 +-
 .../proton/c/api/globals.html                   |     3 +
 .../proton/c/api/globals_c.html                 |     3 +
 .../proton/c/api/globals_defs.html              |     3 +
 .../proton/c/api/globals_func_c.html            |     3 +
 .../proton/c/api/globals_func_l.html            |     8 +-
 .../proton/c/api/globals_func_m.html            |     3 +
 .../proton/c/api/globals_func_n.html            |     9 +
 .../proton/c/api/globals_func_p.html            |     3 +
 .../proton/c/api/globals_func_s.html            |     6 +
 .../proton/c/api/globals_func_t.html            |     6 +
 .../proton/c/api/globals_l.html                 |     8 +-
 .../proton/c/api/globals_m.html                 |     3 +
 .../proton/c/api/globals_n.html                 |     9 +
 .../proton/c/api/globals_p.html                 |     3 +
 .../proton/c/api/globals_s.html                 |     6 +
 .../proton/c/api/globals_t.html                 |    24 +-
 .../proton/c/api/group__api__types.html         |     4 +-
 .../proton/c/api/group__connection.html         |    31 +-
 .../proton/c/api/group__connection__driver.html |    58 +-
 .../proton/c/api/group__connection__driver.js   |     3 +-
 .../proton/c/api/group__data.html               |    22 +-
 .../proton/c/api/group__delivery.html           |    36 +-
 .../proton/c/api/group__error.html              |     6 +-
 .../proton/c/api/group__error.js                |     1 +
 .../proton/c/api/group__event.html              |     4 +-
 .../proton/c/api/group__link.html               |    23 +-
 .../proton/c/api/group__listener.html           |    66 +-
 .../proton/c/api/group__listener.js             |     3 +-
 .../proton/c/api/group__message.html            |    78 +-
 .../proton/c/api/group__message.js              |     1 +
 .../proton/c/api/group__messenger.html          |    33 +-
 .../proton/c/api/group__proactor.html           |   281 +-
 .../proton/c/api/group__proactor.js             |    11 +-
 .../proton/c/api/group__proactor__events.html   |     4 +-
 .../proton/c/api/group__sasl.html               |    29 +-
 .../proton/c/api/group__session.html            |    20 +-
 .../proton/c/api/group__ssl.html                |    84 +
 .../proton/c/api/group__ssl.js                  |     2 +
 .../proton/c/api/group__terminus.html           |     2 +-
 .../proton/c/api/group__transport.html          |   124 +-
 .../proton/c/api/handlers_8h_source.html        |     8 +-
 .../proton/c/api/import__export_8h_source.html  |    10 +-
 .../proton/c/api/link_8h.html                   |     3 +
 .../proton/c/api/link_8h_source.html            |    20 +-
 .../proton/c/api/listener_8h.html               |     8 +-
 .../proton/c/api/listener_8h.js                 |     3 +-
 .../proton/c/api/listener_8h_source.html        |    10 +-
 .../proton/c/api/log_8h_source.html             |     8 +-
 .../proton/c/api/message_8h.html                |     9 +-
 .../proton/c/api/message_8h.js                  |     1 +
 .../proton/c/api/message_8h_source.html         |    21 +-
 .../proton/c/api/messenger_8h.html              |     7 +-
 .../proton/c/api/messenger_8h_source.html       |    38 +-
 .../proton/c/api/navtreedata.js                 |    16 +-
 .../proton/c/api/navtreeindex0.js               |   500 +-
 .../proton/c/api/navtreeindex1.js               |   500 +-
 .../proton/c/api/navtreeindex2.js               |   500 +-
 .../proton/c/api/navtreeindex3.js               |   500 +-
 .../proton/c/api/navtreeindex4.js               |   500 +-
 .../proton/c/api/navtreeindex5.js               |   500 +-
 .../proton/c/api/navtreeindex6.js               |   314 +-
 .../proton/c/api/netaddr_8h.html                |    28 +-
 .../proton/c/api/netaddr_8h.js                  |    10 +-
 .../proton/c/api/netaddr_8h_source.html         |    17 +-
 .../proton/c/api/object_8h_source.html          |    10 +-
 .../qpid-proton-master/proton/c/api/pages.html  |     1 +
 .../proton/c/api/proactor_8h.html               |     6 +-
 .../proton/c/api/proactor_8h.js                 |     1 +
 .../proton/c/api/proactor_8h_source.html        |    12 +-
 .../proton/c/api/reactor_8h_source.html         |    16 +-
 .../proton/c/api/receive_8c-example.html        |     2 +-
 .../proton/c/api/sasl-plugin_8h_source.html     |     6 +-
 .../proton/c/api/sasl_8h.html                   |     5 +-
 .../proton/c/api/sasl_8h_source.html            |     4 +-
 .../proton/c/api/search/all_2.js                |     1 +
 .../proton/c/api/search/all_8.js                |    25 +-
 .../proton/c/api/search/functions_0.js          |    14 +-
 .../proton/c/api/search/pages_0.js              |     3 +-
 .../proton/c/api/search/pages_1.js              |     3 +-
 .../proton/c/api/search/searchdata.js           |     2 +-
 .../proton/c/api/selectable_8h_source.html      |    12 +-
 .../proton/c/api/send_8c-example.html           |     2 +-
 .../proton/c/api/session_8h.html                |     3 +
 .../proton/c/api/session_8h_source.html         |    14 +-
 .../qpid-proton-master/proton/c/api/ssl_8h.html |     6 +
 .../qpid-proton-master/proton/c/api/ssl_8h.js   |     2 +
 .../proton/c/api/ssl_8h_source.html             |    10 +-
 .../proton/c/api/terminus_8h_source.html        |     2 +-
 .../proton/c/api/transport_8h.html              |    14 +-
 .../proton/c/api/transport_8h_source.html       |    18 +-
 .../proton/c/api/type__compat_8h_source.html    |    10 +-
 .../proton/c/api/types_8h_source.html           |    40 +-
 .../proton/c/api/url_8h_source.html             |     4 +-
 .../proton/cpp/api/annotated.html               |    62 +-
 .../proton/cpp/api/broker_8cpp-example.html     |     4 +-
 .../proton/cpp/api/classes.html                 |    56 +-
 .../api/classproton_1_1codec_1_1decoder.html    |     2 +-
 ...classproton_1_1codec_1_1encoder-members.html |     7 +-
 .../api/classproton_1_1codec_1_1encoder.html    |     5 +-
 .../cpp/api/classproton_1_1codec_1_1encoder.js  |     1 +
 .../cpp/api/classproton_1_1connection.html      |    24 +-
 ...ssproton_1_1connection__options-members.html |     2 +-
 .../api/classproton_1_1connection__options.html |    14 +-
 .../api/classproton_1_1connection__options.js   |     2 +-
 .../api/classproton_1_1container-members.html   |    21 +-
 .../cpp/api/classproton_1_1container.html       |   162 +-
 .../proton/cpp/api/classproton_1_1container.js  |     9 +-
 .../proton/cpp/api/classproton_1_1delivery.html |     2 +-
 .../api/classproton_1_1duration-members.html    |    11 +-
 .../proton/cpp/api/classproton_1_1duration.html |     4 +
 .../api/classproton_1_1error__condition.html    |     2 +-
 ...classproton_1_1io_1_1connection__driver.html |     4 +-
 .../proton/cpp/api/classproton_1_1link.html     |     2 +-
 .../classproton_1_1listen__handler-members.html |     9 +-
 .../cpp/api/classproton_1_1listen__handler.html |    24 +-
 .../cpp/api/classproton_1_1listen__handler.js   |     3 +-
 .../api/classproton_1_1listener-members.html    |     7 +-
 .../proton/cpp/api/classproton_1_1listener.html |    69 +-
 .../proton/cpp/api/classproton_1_1listener.js   |     5 +
 .../cpp/api/classproton_1_1message-members.html |     8 +-
 .../proton/cpp/api/classproton_1_1message.html  |   112 +-
 ...assproton_1_1messaging__handler-members.html |    58 +-
 .../api/classproton_1_1messaging__handler.html  |   273 +-
 .../api/classproton_1_1messaging__handler.js    |    58 +-
 .../cpp/api/classproton_1_1null-members.html    |   112 +
 .../proton/cpp/api/classproton_1_1null.html     |   130 +
 .../proton/cpp/api/classproton_1_1null.js       |     5 +
 .../proton/cpp/api/classproton_1_1receiver.html |     6 +-
 ...lassproton_1_1receiver__options-members.html |    15 +-
 .../api/classproton_1_1receiver__options.html   |    17 +-
 .../cpp/api/classproton_1_1receiver__options.js |     3 +-
 .../proton/cpp/api/classproton_1_1returned.html |    29 +-
 .../cpp/api/classproton_1_1sasl-members.html    |     4 -
 .../proton/cpp/api/classproton_1_1sasl.html     |     9 -
 .../proton/cpp/api/classproton_1_1sasl.js       |     4 -
 .../proton/cpp/api/classproton_1_1sender.html   |     6 +-
 .../classproton_1_1sender__options-members.html |    15 +-
 .../cpp/api/classproton_1_1sender__options.html |     8 +-
 .../cpp/api/classproton_1_1sender__options.js   |     3 +-
 .../proton/cpp/api/classproton_1_1session.html  |     2 +-
 .../cpp/api/classproton_1_1source-members.html  |    47 +-
 .../proton/cpp/api/classproton_1_1source.html   |     4 +
 .../proton/cpp/api/classproton_1_1source.js     |     3 +-
 .../classproton_1_1source__options-members.html |    21 +-
 .../cpp/api/classproton_1_1source__options.html |    10 +-
 .../cpp/api/classproton_1_1source__options.js   |     3 +-
 .../cpp/api/classproton_1_1ssl-members.html     |     9 +-
 .../proton/cpp/api/classproton_1_1ssl.html      |     8 -
 .../proton/cpp/api/classproton_1_1ssl.js        |     3 +-
 .../proton/cpp/api/classproton_1_1symbol.html   |     2 +-
 .../cpp/api/classproton_1_1target-members.html  |    33 +-
 .../proton/cpp/api/classproton_1_1target.html   |     4 +
 .../proton/cpp/api/classproton_1_1target.js     |     3 +-
 .../classproton_1_1target__options-members.html |    17 +-
 .../cpp/api/classproton_1_1target__options.html |     4 +
 .../cpp/api/classproton_1_1target__options.js   |     3 +-
 .../api/classproton_1_1terminus-members.html    |    31 +-
 .../proton/cpp/api/classproton_1_1terminus.html |     4 +
 .../proton/cpp/api/classproton_1_1terminus.js   |     3 +-
 .../proton/cpp/api/classproton_1_1tracker.html  |     2 +-
 .../cpp/api/classproton_1_1transport.html       |     2 +-
 .../proton/cpp/api/classproton_1_1url.html      |     3 +-
 .../proton/cpp/api/classproton_1_1uuid.html     |     4 +-
 .../proton/cpp/api/classproton_1_1value.html    |     2 +-
 .../api/classproton_1_1work__queue-members.html |     4 +-
 .../cpp/api/classproton_1_1work__queue.html     |    23 +-
 .../cpp/api/classproton_1_1work__queue.js       |     4 +-
 .../proton/cpp/api/client_8cpp-example.html     |     2 +-
 .../proton/cpp/api/config_8hpp_source.html      |     2 +-
 .../proton/cpp/api/connection_8hpp_source.html  |    10 +-
 .../cpp/api/connection__driver_8hpp_source.html |     6 +-
 .../api/connection__options_8hpp_source.html    |    12 +-
 .../proton/cpp/api/container_8hpp_source.html   |    19 +-
 .../proton/cpp/api/decoder_8hpp_source.html     |     3 +-
 .../proton/cpp/api/default__container_8hpp.html |     7 +-
 .../cpp/api/default__container_8hpp_source.html |     4 +-
 .../proton/cpp/api/deprecated.html              |   111 +
 .../dir_25143d27009f52d175c1d192441a738a.html   |     9 +-
 .../api/dir_25143d27009f52d175c1d192441a738a.js |     5 +-
 .../cpp/api/direct_recv_8cpp-example.html       |     2 +-
 .../cpp/api/direct_send_8cpp-example.html       |     2 +-
 .../proton/cpp/api/duration_8hpp.html           |     3 +
 .../proton/cpp/api/duration_8hpp.js             |     3 +-
 .../proton/cpp/api/duration_8hpp_source.html    |     5 +-
 .../proton/cpp/api/encoder_8hpp_source.html     |     3 +-
 .../proton/cpp/api/endpoint_8hpp_source.html    |     2 +-
 .../cpp/api/error__condition_8hpp_source.html   |     2 +-
 .../proton/cpp/api/examples.html                |     2 -
 .../proton/cpp/api/examples.js                  |     1 -
 .../proton/cpp/api/export_8hpp_source.html      |     2 +-
 .../proton/cpp/api/files.html                   |    65 +-
 .../proton/cpp/api/function_8hpp.html           |     4 +-
 .../proton/cpp/api/functions_c.html             |    14 +-
 .../proton/cpp/api/functions_d.html             |     5 +-
 .../proton/cpp/api/functions_func.html          |     4 +-
 .../proton/cpp/api/functions_func_c.html        |    18 +-
 .../proton/cpp/api/functions_func_d.html        |     5 +-
 .../proton/cpp/api/functions_func_l.html        |     2 +-
 .../proton/cpp/api/functions_func_m.html        |     5 +-
 .../proton/cpp/api/functions_func_n.html        |     5 +
 .../proton/cpp/api/functions_func_o.html        |    77 +-
 .../proton/cpp/api/functions_func_p.html        |     3 +-
 .../proton/cpp/api/functions_func_r.html        |     2 +-
 .../proton/cpp/api/functions_func_s.html        |    13 +-
 .../proton/cpp/api/functions_func_w.html        |     5 +-
 .../proton/cpp/api/functions_l.html             |     4 +-
 .../proton/cpp/api/functions_m.html             |     8 +-
 .../proton/cpp/api/functions_n.html             |     5 +
 .../proton/cpp/api/functions_o.html             |    75 +-
 .../proton/cpp/api/functions_p.html             |     5 +-
 .../proton/cpp/api/functions_r.html             |     2 +-
 .../proton/cpp/api/functions_s.html             |    15 +-
 .../proton/cpp/api/functions_vars.html          |     3 +
 .../proton/cpp/api/functions_w.html             |     5 +-
 .../proton/cpp/api/fwd_8hpp.html                |     3 +-
 .../proton/cpp/api/fwd_8hpp_source.html         |     2 +-
 .../proton/cpp/api/helloworld_8cpp-example.html |     2 +-
 .../proton/cpp/api/hierarchy.html               |    40 +-
 .../proton/cpp/api/hierarchy.js                 |     2 +-
 .../proton/cpp/api/index.html                   |     4 +-
 .../proton/cpp/api/link_8hpp_source.html        |     4 +-
 .../proton/cpp/api/listen__handler_8hpp.html    |     2 +
 .../cpp/api/listen__handler_8hpp_source.html    |     9 +-
 .../proton/cpp/api/listener_8hpp_source.html    |     2 +-
 .../proton/cpp/api/message_8hpp_source.html     |    12 +-
 .../cpp/api/messaging__handler_8hpp_source.html |     6 +-
 .../proton/cpp/api/mt_page.html                 |    16 +-
 .../api/multithreaded_client_8cpp-example.html  |     2 +-
 ...readed_client_flow_control_8cpp-example.html |     2 +-
 .../proton/cpp/api/namespacemembers.html        |     8 +-
 .../proton/cpp/api/namespacemembers_func.html   |    14 +-
 .../proton/cpp/api/namespaceproton.html         |    34 +-
 .../proton/cpp/api/namespaceproton.js           |     2 +-
 .../proton/cpp/api/navtreedata.js               |     9 +-
 .../proton/cpp/api/navtreeindex0.js             |   500 +-
 .../proton/cpp/api/navtreeindex1.js             |   500 +-
 .../proton/cpp/api/navtreeindex2.js             |   500 +-
 .../proton/cpp/api/navtreeindex3.js             |   494 +-
 .../proton/cpp/api/navtreeindex4.js             |   353 +-
 .../proton/cpp/api/null_8hpp.html               |   142 +
 .../proton/cpp/api/null_8hpp.js                 |     5 +
 .../proton/cpp/api/null_8hpp_source.html        |   111 +
 .../proton/cpp/api/object_8hpp_source.html      |     4 +-
 .../proton/cpp/api/pages.html                   |     1 +
 .../cpp/api/pn__unique__ptr_8hpp_source.html    |     2 +-
 .../proton/cpp/api/receiver_8hpp_source.html    |     2 +-
 .../proton/cpp/api/receiver__options_8hpp.html  |     1 +
 .../cpp/api/receiver__options_8hpp_source.html  |    10 +-
 .../cpp/api/reconnect__options_8hpp_source.html |     2 +-
 .../proton/cpp/api/returned_8hpp_source.html    |     2 +-
 .../proton/cpp/api/sasl_8hpp_source.html        |    15 +-
 .../proton/cpp/api/scalar_8hpp.html             |     1 +
 .../proton/cpp/api/scalar_8hpp_source.html      |    14 +-
 .../cpp/api/scalar__base_8hpp_source.html       |     3 +-
 .../cpp/api/scheduled_send_03_8cpp-example.html |     2 +-
 .../cpp/api/scheduled_send_8cpp-example.html    |     2 +-
 .../proton/cpp/api/search/all_0.js              |     2 +-
 .../proton/cpp/api/search/all_13.js             |     1 -
 .../proton/cpp/api/search/all_2.js              |     3 +-
 .../proton/cpp/api/search/all_3.js              |     2 +
 .../proton/cpp/api/search/all_9.js              |     2 +-
 .../proton/cpp/api/search/all_a.js              |     3 +-
 .../proton/cpp/api/search/all_b.js              |     4 +-
 .../proton/cpp/api/search/all_c.js              |    66 +-
 .../proton/cpp/api/search/all_d.js              |     2 +-
 .../proton/cpp/api/search/all_e.js              |     2 +-
 .../proton/cpp/api/search/all_f.js              |     5 +-
 .../proton/cpp/api/search/classes_8.js          |     5 +-
 .../proton/cpp/api/search/classes_9.js          |    19 +-
 .../proton/cpp/api/search/classes_a.js          |    23 +-
 .../proton/cpp/api/search/classes_b.js          |    11 +-
 .../proton/cpp/api/search/classes_c.js          |     4 +-
 .../proton/cpp/api/search/classes_d.js          |     3 +-
 .../proton/cpp/api/search/classes_e.html        |    26 +
 .../proton/cpp/api/search/classes_e.js          |     4 +
 .../proton/cpp/api/search/files_8.js            |     3 +-
 .../proton/cpp/api/search/functions_0.js        |     2 +-
 .../proton/cpp/api/search/functions_13.js       |     1 -
 .../proton/cpp/api/search/functions_2.js        |     3 +-
 .../proton/cpp/api/search/functions_3.js        |     1 +
 .../proton/cpp/api/search/functions_9.js        |     2 +-
 .../proton/cpp/api/search/functions_a.js        |     2 +-
 .../proton/cpp/api/search/functions_b.js        |     5 +-
 .../proton/cpp/api/search/functions_c.js        |    66 +-
 .../proton/cpp/api/search/functions_d.js        |     2 +-
 .../proton/cpp/api/search/functions_e.js        |     2 +-
 .../proton/cpp/api/search/functions_f.js        |     5 +-
 .../proton/cpp/api/search/pages_1.js            |     3 +-
 .../proton/cpp/api/search/pages_2.js            |     3 +-
 .../proton/cpp/api/search/pages_3.js            |     2 +-
 .../proton/cpp/api/search/pages_4.js            |     2 +-
 .../proton/cpp/api/search/pages_5.html          |    26 +
 .../proton/cpp/api/search/pages_5.js            |     4 +
 .../proton/cpp/api/search/searchdata.js         |     4 +-
 .../proton/cpp/api/search/variables_4.js        |     1 +
 .../proton/cpp/api/sender_8hpp_source.html      |     2 +-
 .../proton/cpp/api/sender__options_8hpp.html    |     1 +
 .../cpp/api/sender__options_8hpp_source.html    |     8 +-
 .../proton/cpp/api/server_8cpp-example.html     |     2 +-
 .../cpp/api/server_direct_8cpp-example.html     |     2 +-
 .../cpp/api/service_bus_8cpp-example.html       |     2 +-
 .../proton/cpp/api/session_8hpp_source.html     |     8 +-
 .../cpp/api/session__options_8hpp_source.html   |     2 +-
 .../cpp/api/simple_recv_8cpp-example.html       |     2 +-
 .../cpp/api/simple_send_8cpp-example.html       |     2 +-
 .../proton/cpp/api/source_8hpp_source.html      |     2 +-
 .../cpp/api/source__options_8hpp_source.html    |    13 +-
 .../proton/cpp/api/ssl_8hpp.html                |     1 +
 .../proton/cpp/api/ssl_8hpp_source.html         |    24 +-
 .../proton/cpp/api/target_8hpp_source.html      |     2 +-
 .../cpp/api/target__options_8hpp_source.html    |    11 +-
 .../proton/cpp/api/terminus_8hpp.html           |     1 +
 .../proton/cpp/api/terminus_8hpp_source.html    |     6 +-
 .../proton/cpp/api/thread__safe_8hpp.html       |     4 +-
 .../cpp/api/thread__safe_8hpp_source.html       |     2 +-
 .../proton/cpp/api/tracker_8hpp_source.html     |     2 +-
 .../proton/cpp/api/transfer_8hpp_source.html    |     4 +-
 .../proton/cpp/api/transport_8hpp_source.html   |     2 +-
 .../proton/cpp/api/tutorial_page.html           |    59 +-
 .../cpp/api/type__traits_8hpp_source.html       |     2 +-
 .../proton/cpp/api/types_8hpp.html              |     2 +-
 .../proton/cpp/api/types_8hpp_source.html       |     4 +-
 .../proton/cpp/api/types__fwd_8hpp.html         |     1 -
 .../proton/cpp/api/types__fwd_8hpp_source.html  |     2 +-
 .../proton/cpp/api/url_8hpp_source.html         |    23 +-
 .../proton/cpp/api/uuid_8hpp.html               |     2 +-
 .../proton/cpp/api/uuid_8hpp_source.html        |     2 +-
 .../proton/cpp/api/value_8hpp_source.html       |     7 +-
 .../proton/cpp/api/work__queue_8hpp.html        |    26 +-
 .../proton/cpp/api/work__queue_8hpp_source.html |    14 +-
 .../proton/cpp/examples/broker.cpp              |    48 +-
 .../proton/cpp/examples/broker.cpp.html         |    48 +-
 .../proton/cpp/examples/colour_send.cpp         |   116 +
 .../proton/cpp/examples/colour_send.cpp.html    |   244 +
 .../proton/cpp/examples/direct_recv.cpp         |    11 +-
 .../proton/cpp/examples/direct_recv.cpp.html    |    11 +-
 .../proton/cpp/examples/direct_send.cpp         |    11 +-
 .../proton/cpp/examples/direct_send.cpp.html    |    11 +-
 .../proton/cpp/examples/encode_decode.cpp       |     2 +-
 .../proton/cpp/examples/encode_decode.cpp.html  |     2 +-
 .../proton/cpp/examples/flow_control.cpp        |    30 +-
 .../proton/cpp/examples/flow_control.cpp.html   |    30 +-
 .../proton/cpp/examples/helloworld.cpp          |    19 +-
 .../proton/cpp/examples/helloworld.cpp.html     |    19 +-
 .../proton/cpp/examples/index.html              |     7 +-
 .../cpp/examples/multithreaded_client.cpp       |     4 +-
 .../cpp/examples/multithreaded_client.cpp.html  |     4 +-
 .../multithreaded_client_flow_control.cpp       |    11 +-
 .../multithreaded_client_flow_control.cpp.html  |    11 +-
 .../proton/cpp/examples/queue_browser.cpp       |    34 +-
 .../proton/cpp/examples/queue_browser.cpp.html  |    34 +-
 .../proton/cpp/examples/reconnect_client.cpp    |     3 +-
 .../cpp/examples/reconnect_client.cpp.html      |     3 +-
 .../proton/cpp/examples/scheduled_send.cpp      |     1 +
 .../proton/cpp/examples/scheduled_send.cpp.html |     1 +
 .../proton/cpp/examples/scheduled_send_03.cpp   |     8 +-
 .../cpp/examples/scheduled_send_03.cpp.html     |     8 +-
 .../proton/cpp/examples/selected_recv.cpp       |    19 +-
 .../proton/cpp/examples/selected_recv.cpp.html  |    19 +-
 .../proton/cpp/examples/server.cpp              |    53 +-
 .../proton/cpp/examples/server.cpp.html         |    55 +-
 .../proton/cpp/examples/server_direct.cpp       |    11 +-
 .../proton/cpp/examples/server_direct.cpp.html  |    11 +-
 .../proton/cpp/examples/service_bus.cpp         |    22 +-
 .../proton/cpp/examples/service_bus.cpp.html    |    22 +-
 .../proton/cpp/examples/simple_connect.cpp      |   111 +
 .../proton/cpp/examples/simple_connect.cpp.html |   239 +
 .../proton/cpp/examples/simple_recv.cpp         |     1 -
 .../proton/cpp/examples/simple_recv.cpp.html    |     1 -
 .../proton/cpp/examples/ssl.cpp                 |    49 +-
 .../proton/cpp/examples/ssl.cpp.html            |    49 +-
 .../proton/cpp/examples/ssl_client_cert.cpp     |    31 +-
 .../cpp/examples/ssl_client_cert.cpp.html       |    31 +-
 .../proton/python/api/api-objects.txt           |    73 +-
 .../proton/python/api/class-tree.html           |    19 +-
 .../proton/python/api/identifier-index.html     |  1402 ++-
 .../proton/python/api/proton-module.html        |    39 +-
 .../proton/python/api/proton-pysrc.html         |  8611 +++++++-------
 .../python/api/proton.Delivery-class.html       |    59 +-
 .../proton/python/api/proton.Handler-class.html |     2 +-
 .../python/api/proton.Interrupt-class.html      |     2 +-
 .../proton/python/api/proton.Link-class.html    |     4 +-
 .../api/proton.MessageException-class.html      |     2 +-
 .../api/proton.ProtonException-class.html       |     2 +-
 .../proton/python/api/proton.Url-class.html     |     5 +-
 .../python/api/proton._compat-module.html       |    17 +
 .../proton/python/api/proton._compat-pysrc.html |    75 +-
 .../python/api/proton.handlers-pysrc.html       |  1377 ++-
 .../api/proton.handlers.Acking-class.html       |    26 +-
 ...n.handlers.IncomingMessageHandler-class.html |    19 +-
 .../proton.handlers.MessagingHandler-class.html |     6 +-
 ...n.handlers.OutgoingMessageHandler-class.html |     2 +-
 ...ndlers.TransactionalClientHandler-class.html |     2 +
 .../python/api/proton.reactor-module.html       |     2 +-
 .../proton/python/api/proton.reactor-pysrc.html |  1368 ++-
 .../api/proton.reactor.Container-class.html     |    34 +-
 .../api/proton.reactor.EventInjector-class.html |     2 +-
 .../api/proton.reactor.Reactor-class.html       |     2 +-
 .../proton/python/api/proton.utils-module.html  |     2 +-
 .../proton/python/api/proton.utils-pysrc.html   |  1199 +-
 .../python/api/proton.utils.Fetcher-class.html  |     2 +-
 .../proton.utils.SyncRequestResponse-class.html |     5 +-
 .../python/api/proton.wrapper-module.html       |     2 +-
 .../proton/python/api/proton.wrapper-pysrc.html |   147 +-
 .../proton/python/api/redirect.html             |     2 +-
 .../proton/python/api/toc-everything.html       |    10 +-
 .../proton/python/api/toc-proton-module.html    |    10 +-
 .../proton/python/book/.buildinfo               |     2 +-
 .../proton/python/book/_sources/index.rst.txt   |    11 +
 .../python/book/_sources/overview.rst.txt       |   160 +
 .../python/book/_sources/tutorial.rst.txt       |   301 +
 .../proton/python/book/_static/basic.css        |    59 +-
 .../python/book/_static/comment-bright.png      |   Bin 3500 -> 756 bytes
 .../python/book/_static/comment-close.png       |   Bin 3578 -> 829 bytes
 .../proton/python/book/_static/comment.png      |   Bin 3445 -> 641 bytes
 .../proton/python/book/_static/contents.png     |   Bin 202 -> 107 bytes
 .../proton/python/book/_static/doctools.js      |     2 +-
 .../proton/python/book/_static/down-pressed.png |   Bin 347 -> 222 bytes
 .../proton/python/book/_static/down.png         |   Bin 347 -> 202 bytes
 .../proton/python/book/_static/file.png         |   Bin 358 -> 286 bytes
 .../proton/python/book/_static/jquery-3.1.0.js  | 10074 +++++++++++++++++
 .../proton/python/book/_static/jquery.js        |     8 +-
 .../proton/python/book/_static/minus.png        |   Bin 173 -> 90 bytes
 .../proton/python/book/_static/navigation.png   |   Bin 218 -> 120 bytes
 .../proton/python/book/_static/plus.png         |   Bin 173 -> 90 bytes
 .../proton/python/book/_static/pygments.css     |     4 +
 .../proton/python/book/_static/searchtools.js   |   117 +-
 .../proton/python/book/_static/sphinxdoc.css    |     2 +-
 .../proton/python/book/_static/up-pressed.png   |   Bin 345 -> 214 bytes
 .../proton/python/book/_static/up.png           |   Bin 345 -> 203 bytes
 .../proton/python/book/_static/websupport.js    |     2 +-
 .../proton/python/book/genindex.html            |   820 +-
 .../proton/python/book/index.html               |    16 +-
 .../proton/python/book/objects.inv              |     2 +-
 .../proton/python/book/overview.html            |    63 +-
 .../proton/python/book/search.html              |    14 +-
 .../proton/python/book/searchindex.js           |     2 +-
 .../proton/python/book/tutorial.html            |   106 +-
 .../proton/python/examples/colour_send.py       |    68 +
 .../proton/python/examples/colour_send.py.html  |   197 +
 .../proton/python/examples/index.html           |     5 +-
 .../proton/python/examples/selected_recv.py     |    26 +-
 .../python/examples/selected_recv.py.html       |    26 +-
 .../proton/python/examples/sync_client.py       |     2 +-
 .../proton/python/examples/sync_client.py.html  |     2 +-
 .../proton/python/examples/test_examples.py     |    17 +
 .../python/examples/test_examples.py.html       |    17 +
 .../proton/ruby/api/Qpid.html                   |   128 +
 .../proton/ruby/api/Qpid/Proton.html            |   349 +
 .../ruby/api/Qpid/Proton/AbortedError.html      |   143 +
 .../ruby/api/Qpid/Proton/ArgumentError.html     |   143 +
 .../ruby/api/Qpid/Proton/AttributeError.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/Condition.html  |   827 ++
 .../proton/ruby/api/Qpid/Proton/Connection.html |  3001 +++++
 .../ruby/api/Qpid/Proton/ConnectionDriver.html  |  1663 +++
 .../proton/ruby/api/Qpid/Proton/Container.html  |  2203 ++++
 .../Qpid/Proton/Container/ConnectionTask.html   |   441 +
 .../api/Qpid/Proton/Container/ListenTask.html   |  1017 ++
 .../api/Qpid/Proton/Container/SelectWaker.html  |   482 +
 .../api/Qpid/Proton/Container/StoppedError.html |   237 +
 .../proton/ruby/api/Qpid/Proton/Delivery.html   |  1009 ++
 .../ruby/api/Qpid/Proton/Disposition.html       |   899 ++
 .../proton/ruby/api/Qpid/Proton/EOSError.html   |   143 +
 .../proton/ruby/api/Qpid/Proton/Endpoint.html   |  1082 ++
 .../proton/ruby/api/Qpid/Proton/Event.html      |  1429 +++
 .../proton/ruby/api/Qpid/Proton/Handler.html    |   213 +
 .../ruby/api/Qpid/Proton/Handler/Adapter.html   |   497 +
 .../api/Qpid/Proton/Handler/ArrayHandler.html   |   602 +
 .../Qpid/Proton/Handler/MessagingAdapter.html   |  1104 ++
 .../Qpid/Proton/Handler/MessagingHandler.html   |   482 +
 .../Proton/Handler/ReactorMessagingAdapter.html |  1139 ++
 .../ruby/api/Qpid/Proton/HandlerDriver.html     |   576 +
 .../ruby/api/Qpid/Proton/InProgressError.html   |   141 +
 .../ruby/api/Qpid/Proton/InterruptedError.html  |   143 +
 .../proton/ruby/api/Qpid/Proton/Link.html       |  1795 +++
 .../proton/ruby/api/Qpid/Proton/LinkError.html  |   143 +
 .../proton/ruby/api/Qpid/Proton/Listener.html   |   649 ++
 .../ruby/api/Qpid/Proton/Listener/Handler.html  |   598 +
 .../proton/ruby/api/Qpid/Proton/Message.html    |  4278 +++++++
 .../ruby/api/Qpid/Proton/MessagingHandler.html  |   246 +
 .../ruby/api/Qpid/Proton/OverflowError.html     |   143 +
 .../ruby/api/Qpid/Proton/ProtonError.html       |   139 +
 .../proton/ruby/api/Qpid/Proton/Reactor.html    |   124 +
 .../ruby/api/Qpid/Proton/Reactor/Container.html |   551 +
 .../proton/ruby/api/Qpid/Proton/Receiver.html   |   881 ++
 .../proton/ruby/api/Qpid/Proton/Reject.html     |   143 +
 .../proton/ruby/api/Qpid/Proton/Release.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/SASL.html       |   603 +
 .../proton/ruby/api/Qpid/Proton/SASLError.html  |   151 +
 .../proton/ruby/api/Qpid/Proton/SSL.html        |   700 ++
 .../proton/ruby/api/Qpid/Proton/SSLDomain.html  |   721 ++
 .../proton/ruby/api/Qpid/Proton/SSLError.html   |   153 +
 .../api/Qpid/Proton/SSLUnavailableError.html    |   157 +
 .../proton/ruby/api/Qpid/Proton/Sender.html     |   874 ++
 .../proton/ruby/api/Qpid/Proton/Session.html    |  1039 ++
 .../ruby/api/Qpid/Proton/SessionError.html      |   143 +
 .../proton/ruby/api/Qpid/Proton/StateError.html |   148 +
 .../ruby/api/Qpid/Proton/StopAutoResponse.html  |   144 +
 .../ruby/api/Qpid/Proton/StoppedError.html      |   155 +
 .../proton/ruby/api/Qpid/Proton/Terminus.html   |  1207 ++
 .../ruby/api/Qpid/Proton/TimeoutError.html      |   143 +
 .../proton/ruby/api/Qpid/Proton/Tracker.html    |   452 +
 .../proton/ruby/api/Qpid/Proton/Transfer.html   |  1307 +++
 .../ruby/api/Qpid/Proton/Transfer/State.html    |   209 +
 .../proton/ruby/api/Qpid/Proton/Transport.html  |  1957 ++++
 .../ruby/api/Qpid/Proton/TransportError.html    |   147 +
 .../proton/ruby/api/Qpid/Proton/Types.html      |   481 +
 .../ruby/api/Qpid/Proton/Types/ArrayHeader.html |   502 +
 .../api/Qpid/Proton/Types/BinaryString.html     |   136 +
 .../ruby/api/Qpid/Proton/Types/Described.html   |   133 +
 .../proton/ruby/api/Qpid/Proton/Types/Type.html |   533 +
 .../ruby/api/Qpid/Proton/Types/UTFString.html   |   226 +
 .../api/Qpid/Proton/Types/UniformArray.html     |   685 ++
 .../proton/ruby/api/Qpid/Proton/URL.html        |   854 ++
 .../ruby/api/Qpid/Proton/UnderflowError.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/Util.html       |   132 +
 .../proton/ruby/api/Qpid/Proton/WorkQueue.html  |   439 +
 .../api/Qpid/Proton/WorkQueue/StoppedError.html |   237 +
 .../proton/ruby/api/_index.html                 |   731 ++
 .../proton/ruby/api/class_list.html             |    51 +
 .../proton/ruby/api/css/common.css              |     1 +
 .../proton/ruby/api/css/full_list.css           |    58 +
 .../proton/ruby/api/css/style.css               |   492 +
 .../proton/ruby/api/file.README.html            |   229 +
 .../proton/ruby/api/file_list.html              |    56 +
 .../proton/ruby/api/frames.html                 |    17 +
 .../proton/ruby/api/index.html                  |   229 +
 .../proton/ruby/api/js/app.js                   |   243 +
 .../proton/ruby/api/js/full_list.js             |   216 +
 .../proton/ruby/api/js/jquery.js                |     4 +
 .../proton/ruby/api/method_list.html            |  3091 +++++
 .../proton/ruby/examples/broker.rb              |   174 +
 .../proton/ruby/examples/broker.rb.html         |   304 +
 .../proton/ruby/examples/client.rb              |    79 +
 .../proton/ruby/examples/client.rb.html         |   209 +
 .../proton/ruby/examples/direct_recv.rb         |    61 +
 .../proton/ruby/examples/direct_recv.rb.html    |   190 +
 .../proton/ruby/examples/direct_send.rb         |    67 +
 .../proton/ruby/examples/direct_send.rb.html    |   197 +
 .../proton/ruby/examples/example_test.rb        |   109 +
 .../proton/ruby/examples/example_test.rb.html   |   238 +
 .../proton/ruby/examples/helloworld.rb          |    57 +
 .../proton/ruby/examples/helloworld.rb.html     |   187 +
 .../proton/ruby/examples/index.html             |   167 +
 .../proton/ruby/examples/server.rb              |    70 +
 .../proton/ruby/examples/server.rb.html         |   200 +
 .../proton/ruby/examples/simple_recv.rb         |    57 +
 .../proton/ruby/examples/simple_recv.rb.html    |   186 +
 .../proton/ruby/examples/simple_send.rb         |    63 +
 .../proton/ruby/examples/simple_send.rb.html    |   193 +
 .../proton/ruby/examples/ssl_send.rb            |    70 +
 .../proton/ruby/examples/ssl_send.rb.html       |   200 +
 input/releases/qpid-proton-master/index.md      |     8 +-
 .../proton/c/api/annotated.html                 |     2 +-
 .../proton/c/api/broker_8c-example.html         |   108 +
 .../proton/c/api/cid_8h_source.html             |   108 +
 .../proton/c/api/codec_8h.html                  |     6 +-
 .../proton/c/api/codec_8h_source.html           |    18 +-
 .../proton/c/api/connection_8h.html             |     7 +-
 .../proton/c/api/connection_8h_source.html      |    18 +-
 .../proton/c/api/connection__driver_8h.html     |    23 +-
 .../proton/c/api/connection__driver_8h.js       |     3 +-
 .../c/api/connection__driver_8h_source.html     |    23 +-
 .../proton/c/api/delivery_8h.html               |     6 +-
 .../proton/c/api/delivery_8h_source.html        |    18 +-
 .../proton/c/api/deprecated.html                |   119 +
 .../api/dir_25143d27009f52d175c1d192441a738a.js |    10 +
 .../proton/c/api/direct_8c-example.html         |   108 +
 .../proton/c/api/engine_8h_source.html          |   116 +
 .../proton/c/api/error_8h.html                  |     6 +-
 .../qpid-proton-master/proton/c/api/error_8h.js |     1 +
 .../proton/c/api/error_8h_source.html           |     2 +-
 .../proton/c/api/event_8h_source.html           |    16 +-
 .../proton/c/api/examples.html                  |   117 +
 .../qpid-proton-master/proton/c/api/examples.js |     7 +
 .../qpid-proton-master/proton/c/api/files.html  |    52 +-
 .../proton/c/api/globals.html                   |     3 +
 .../proton/c/api/globals_c.html                 |     3 +
 .../proton/c/api/globals_defs.html              |     3 +
 .../proton/c/api/globals_func_c.html            |     3 +
 .../proton/c/api/globals_func_l.html            |     8 +-
 .../proton/c/api/globals_func_m.html            |     3 +
 .../proton/c/api/globals_func_n.html            |     9 +
 .../proton/c/api/globals_func_p.html            |     3 +
 .../proton/c/api/globals_func_s.html            |     6 +
 .../proton/c/api/globals_func_t.html            |     6 +
 .../proton/c/api/globals_l.html                 |     8 +-
 .../proton/c/api/globals_m.html                 |     3 +
 .../proton/c/api/globals_n.html                 |     9 +
 .../proton/c/api/globals_p.html                 |     3 +
 .../proton/c/api/globals_s.html                 |     6 +
 .../proton/c/api/globals_t.html                 |    24 +-
 .../proton/c/api/group__api__types.html         |     4 +-
 .../proton/c/api/group__connection.html         |    31 +-
 .../proton/c/api/group__connection__driver.html |    58 +-
 .../proton/c/api/group__connection__driver.js   |     3 +-
 .../proton/c/api/group__data.html               |    22 +-
 .../proton/c/api/group__delivery.html           |    36 +-
 .../proton/c/api/group__error.html              |     6 +-
 .../proton/c/api/group__error.js                |     1 +
 .../proton/c/api/group__event.html              |     4 +-
 .../proton/c/api/group__link.html               |    23 +-
 .../proton/c/api/group__listener.html           |    66 +-
 .../proton/c/api/group__listener.js             |     3 +-
 .../proton/c/api/group__message.html            |    78 +-
 .../proton/c/api/group__message.js              |     1 +
 .../proton/c/api/group__messenger.html          |    33 +-
 .../proton/c/api/group__proactor.html           |   281 +-
 .../proton/c/api/group__proactor.js             |    11 +-
 .../proton/c/api/group__proactor__events.html   |     4 +-
 .../proton/c/api/group__sasl.html               |    29 +-
 .../proton/c/api/group__session.html            |    20 +-
 .../proton/c/api/group__ssl.html                |    84 +
 .../proton/c/api/group__ssl.js                  |     2 +
 .../proton/c/api/group__terminus.html           |     2 +-
 .../proton/c/api/group__transport.html          |   124 +-
 .../proton/c/api/handlers_8h_source.html        |   108 +
 .../proton/c/api/import__export_8h_source.html  |   108 +
 .../proton/c/api/link_8h.html                   |     3 +
 .../proton/c/api/link_8h_source.html            |    20 +-
 .../proton/c/api/listener_8h.html               |     8 +-
 .../proton/c/api/listener_8h.js                 |     3 +-
 .../proton/c/api/listener_8h_source.html        |    10 +-
 .../proton/c/api/log_8h_source.html             |   108 +
 .../proton/c/api/message_8h.html                |     9 +-
 .../proton/c/api/message_8h.js                  |     1 +
 .../proton/c/api/message_8h_source.html         |    21 +-
 .../proton/c/api/messenger_8h.html              |     7 +-
 .../proton/c/api/messenger_8h_source.html       |    38 +-
 .../proton/c/api/navtreedata.js                 |    16 +-
 .../proton/c/api/navtreeindex0.js               |   500 +-
 .../proton/c/api/navtreeindex1.js               |   500 +-
 .../proton/c/api/navtreeindex2.js               |   500 +-
 .../proton/c/api/navtreeindex3.js               |   500 +-
 .../proton/c/api/navtreeindex4.js               |   500 +-
 .../proton/c/api/navtreeindex5.js               |   500 +-
 .../proton/c/api/navtreeindex6.js               |   314 +-
 .../proton/c/api/netaddr_8h.html                |    28 +-
 .../proton/c/api/netaddr_8h.js                  |    10 +-
 .../proton/c/api/netaddr_8h_source.html         |    17 +-
 .../proton/c/api/object_8h_source.html          |   109 +
 .../qpid-proton-master/proton/c/api/pages.html  |     1 +
 .../proton/c/api/proactor_8h.html               |     6 +-
 .../proton/c/api/proactor_8h.js                 |     1 +
 .../proton/c/api/proactor_8h_source.html        |    12 +-
 .../proton/c/api/reactor_8h_source.html         |   119 +
 .../proton/c/api/receive_8c-example.html        |   108 +
 .../proton/c/api/sasl-plugin_8h_source.html     |   111 +
 .../proton/c/api/sasl_8h.html                   |     5 +-
 .../proton/c/api/sasl_8h_source.html            |     4 +-
 .../proton/c/api/search/all_2.js                |     1 +
 .../proton/c/api/search/all_8.js                |    25 +-
 .../proton/c/api/search/functions_0.js          |    14 +-
 .../proton/c/api/search/pages_0.js              |     3 +-
 .../proton/c/api/search/pages_1.html            |    26 +
 .../proton/c/api/search/pages_1.js              |     5 +
 .../proton/c/api/search/searchdata.js           |     2 +-
 .../proton/c/api/selectable_8h_source.html      |   111 +
 .../proton/c/api/send_8c-example.html           |   108 +
 .../proton/c/api/session_8h.html                |     3 +
 .../proton/c/api/session_8h_source.html         |    14 +-
 .../qpid-proton-master/proton/c/api/ssl_8h.html |     6 +
 .../qpid-proton-master/proton/c/api/ssl_8h.js   |     2 +
 .../proton/c/api/ssl_8h_source.html             |    10 +-
 .../proton/c/api/terminus_8h_source.html        |     2 +-
 .../proton/c/api/transport_8h.html              |    14 +-
 .../proton/c/api/transport_8h_source.html       |    18 +-
 .../proton/c/api/type__compat_8h_source.html    |   108 +
 .../proton/c/api/types_8h_source.html           |    40 +-
 .../proton/c/api/url_8h_source.html             |     4 +-
 .../proton/cpp/api/annotated.html               |    62 +-
 .../proton/cpp/api/broker_8cpp-example.html     |     4 +-
 .../proton/cpp/api/classes.html                 |    56 +-
 .../api/classproton_1_1codec_1_1decoder.html    |     2 +-
 ...classproton_1_1codec_1_1encoder-members.html |     7 +-
 .../api/classproton_1_1codec_1_1encoder.html    |     5 +-
 .../cpp/api/classproton_1_1codec_1_1encoder.js  |     1 +
 .../cpp/api/classproton_1_1connection.html      |    24 +-
 ...ssproton_1_1connection__options-members.html |     2 +-
 .../api/classproton_1_1connection__options.html |    14 +-
 .../api/classproton_1_1connection__options.js   |     2 +-
 .../api/classproton_1_1container-members.html   |    21 +-
 .../cpp/api/classproton_1_1container.html       |   162 +-
 .../proton/cpp/api/classproton_1_1container.js  |     9 +-
 .../proton/cpp/api/classproton_1_1delivery.html |     2 +-
 .../api/classproton_1_1duration-members.html    |    11 +-
 .../proton/cpp/api/classproton_1_1duration.html |     4 +
 .../api/classproton_1_1error__condition.html    |     2 +-
 ...classproton_1_1io_1_1connection__driver.html |     4 +-
 .../proton/cpp/api/classproton_1_1link.html     |     2 +-
 .../classproton_1_1listen__handler-members.html |     9 +-
 .../cpp/api/classproton_1_1listen__handler.html |    24 +-
 .../cpp/api/classproton_1_1listen__handler.js   |     3 +-
 .../api/classproton_1_1listener-members.html    |     7 +-
 .../proton/cpp/api/classproton_1_1listener.html |    69 +-
 .../proton/cpp/api/classproton_1_1listener.js   |     5 +
 .../cpp/api/classproton_1_1message-members.html |     8 +-
 .../proton/cpp/api/classproton_1_1message.html  |   112 +-
 ...assproton_1_1messaging__handler-members.html |    58 +-
 .../api/classproton_1_1messaging__handler.html  |   273 +-
 .../api/classproton_1_1messaging__handler.js    |    58 +-
 .../cpp/api/classproton_1_1null-members.html    |   112 +
 .../proton/cpp/api/classproton_1_1null.html     |   130 +
 .../proton/cpp/api/classproton_1_1null.js       |     5 +
 .../proton/cpp/api/classproton_1_1receiver.html |     6 +-
 ...lassproton_1_1receiver__options-members.html |    15 +-
 .../api/classproton_1_1receiver__options.html   |    17 +-
 .../cpp/api/classproton_1_1receiver__options.js |     3 +-
 .../proton/cpp/api/classproton_1_1returned.html |    29 +-
 .../cpp/api/classproton_1_1sasl-members.html    |     4 -
 .../proton/cpp/api/classproton_1_1sasl.html     |     9 -
 .../proton/cpp/api/classproton_1_1sasl.js       |     4 -
 .../proton/cpp/api/classproton_1_1sender.html   |     6 +-
 .../classproton_1_1sender__options-members.html |    15 +-
 .../cpp/api/classproton_1_1sender__options.html |     8 +-
 .../cpp/api/classproton_1_1sender__options.js   |     3 +-
 .../proton/cpp/api/classproton_1_1session.html  |     2 +-
 .../cpp/api/classproton_1_1source-members.html  |    47 +-
 .../proton/cpp/api/classproton_1_1source.html   |     4 +
 .../proton/cpp/api/classproton_1_1source.js     |     3 +-
 .../classproton_1_1source__options-members.html |    21 +-
 .../cpp/api/classproton_1_1source__options.html |    10 +-
 .../cpp/api/classproton_1_1source__options.js   |     3 +-
 .../cpp/api/classproton_1_1ssl-members.html     |     9 +-
 .../proton/cpp/api/classproton_1_1ssl.html      |     8 -
 .../proton/cpp/api/classproton_1_1ssl.js        |     3 +-
 .../proton/cpp/api/classproton_1_1symbol.html   |     2 +-
 .../cpp/api/classproton_1_1target-members.html  |    33 +-
 .../proton/cpp/api/classproton_1_1target.html   |     4 +
 .../proton/cpp/api/classproton_1_1target.js     |     3 +-
 .../classproton_1_1target__options-members.html |    17 +-
 .../cpp/api/classproton_1_1target__options.html |     4 +
 .../cpp/api/classproton_1_1target__options.js   |     3 +-
 .../api/classproton_1_1terminus-members.html    |    31 +-
 .../proton/cpp/api/classproton_1_1terminus.html |     4 +
 .../proton/cpp/api/classproton_1_1terminus.js   |     3 +-
 .../proton/cpp/api/classproton_1_1tracker.html  |     2 +-
 .../cpp/api/classproton_1_1transport.html       |     2 +-
 .../proton/cpp/api/classproton_1_1url.html      |     3 +-
 .../proton/cpp/api/classproton_1_1uuid.html     |     4 +-
 .../proton/cpp/api/classproton_1_1value.html    |     2 +-
 .../cpp/api/classproton_1_1work-members.html    |   114 -
 .../proton/cpp/api/classproton_1_1work.html     |   168 -
 .../proton/cpp/api/classproton_1_1work.js       |     7 -
 .../api/classproton_1_1work__queue-members.html |     4 +-
 .../cpp/api/classproton_1_1work__queue.html     |    23 +-
 .../cpp/api/classproton_1_1work__queue.js       |     4 +-
 .../proton/cpp/api/client_8cpp-example.html     |     2 +-
 .../proton/cpp/api/config_8hpp_source.html      |     2 +-
 .../proton/cpp/api/connection_8hpp_source.html  |    10 +-
 .../cpp/api/connection__driver_8hpp_source.html |     6 +-
 .../api/connection__options_8hpp_source.html    |    12 +-
 .../proton/cpp/api/container_8hpp_source.html   |    19 +-
 .../proton/cpp/api/decoder_8hpp_source.html     |     3 +-
 .../proton/cpp/api/default__container_8hpp.html |     7 +-
 .../cpp/api/default__container_8hpp_source.html |     4 +-
 .../proton/cpp/api/deprecated.html              |   111 +
 .../dir_25143d27009f52d175c1d192441a738a.html   |     9 +-
 .../api/dir_25143d27009f52d175c1d192441a738a.js |     5 +-
 .../cpp/api/direct_recv_8cpp-example.html       |     2 +-
 .../cpp/api/direct_send_8cpp-example.html       |     2 +-
 .../proton/cpp/api/duration_8hpp.html           |     3 +
 .../proton/cpp/api/duration_8hpp.js             |     3 +-
 .../proton/cpp/api/duration_8hpp_source.html    |     5 +-
 .../proton/cpp/api/encoder_8hpp_source.html     |     3 +-
 .../proton/cpp/api/endpoint_8hpp_source.html    |     2 +-
 .../cpp/api/error__condition_8hpp_source.html   |     2 +-
 .../proton/cpp/api/examples.html                |     2 -
 .../proton/cpp/api/examples.js                  |     1 -
 .../proton/cpp/api/export_8hpp_source.html      |     2 +-
 .../proton/cpp/api/files.html                   |    65 +-
 .../proton/cpp/api/function_8hpp.html           |     4 +-
 .../proton/cpp/api/functions_c.html             |    14 +-
 .../proton/cpp/api/functions_d.html             |     5 +-
 .../proton/cpp/api/functions_func.html          |     4 +-
 .../proton/cpp/api/functions_func_c.html        |    18 +-
 .../proton/cpp/api/functions_func_d.html        |     5 +-
 .../proton/cpp/api/functions_func_l.html        |     2 +-
 .../proton/cpp/api/functions_func_m.html        |     5 +-
 .../proton/cpp/api/functions_func_n.html        |     5 +
 .../proton/cpp/api/functions_func_o.html        |    77 +-
 .../proton/cpp/api/functions_func_p.html        |     3 +-
 .../proton/cpp/api/functions_func_r.html        |     2 +-
 .../proton/cpp/api/functions_func_s.html        |    13 +-
 .../proton/cpp/api/functions_func_w.html        |     5 +-
 .../proton/cpp/api/functions_l.html             |     4 +-
 .../proton/cpp/api/functions_m.html             |     8 +-
 .../proton/cpp/api/functions_n.html             |     5 +
 .../proton/cpp/api/functions_o.html             |    75 +-
 .../proton/cpp/api/functions_p.html             |     5 +-
 .../proton/cpp/api/functions_r.html             |     2 +-
 .../proton/cpp/api/functions_s.html             |    15 +-
 .../proton/cpp/api/functions_vars.html          |     3 +
 .../proton/cpp/api/functions_w.html             |     5 +-
 .../proton/cpp/api/fwd_8hpp.html                |     3 +-
 .../proton/cpp/api/fwd_8hpp_source.html         |     2 +-
 .../proton/cpp/api/helloworld_8cpp-example.html |     2 +-
 .../cpp/api/helloworld_direct_8cpp-example.html |   108 -
 .../proton/cpp/api/hierarchy.html               |    40 +-
 .../proton/cpp/api/hierarchy.js                 |     2 +-
 .../proton/cpp/api/index.html                   |     4 +-
 .../proton/cpp/api/link_8hpp_source.html        |     4 +-
 .../proton/cpp/api/listen__handler_8hpp.html    |     2 +
 .../cpp/api/listen__handler_8hpp_source.html    |     9 +-
 .../proton/cpp/api/listener_8hpp_source.html    |     2 +-
 .../proton/cpp/api/message_8hpp_source.html     |    12 +-
 .../cpp/api/messaging__handler_8hpp_source.html |     6 +-
 .../proton/cpp/api/mt_page.html                 |    16 +-
 .../api/multithreaded_client_8cpp-example.html  |     2 +-
 ...readed_client_flow_control_8cpp-example.html |     2 +-
 .../proton/cpp/api/namespacemembers.html        |     8 +-
 .../proton/cpp/api/namespacemembers_func.html   |    14 +-
 .../proton/cpp/api/namespaceproton.html         |    34 +-
 .../proton/cpp/api/namespaceproton.js           |     2 +-
 .../proton/cpp/api/navtreedata.js               |     9 +-
 .../proton/cpp/api/navtreeindex0.js             |   500 +-
 .../proton/cpp/api/navtreeindex1.js             |   500 +-
 .../proton/cpp/api/navtreeindex2.js             |   500 +-
 .../proton/cpp/api/navtreeindex3.js             |   494 +-
 .../proton/cpp/api/navtreeindex4.js             |   353 +-
 .../proton/cpp/api/null_8hpp.html               |   142 +
 .../proton/cpp/api/null_8hpp.js                 |     5 +
 .../proton/cpp/api/null_8hpp_source.html        |   111 +
 .../proton/cpp/api/object_8hpp_source.html      |     4 +-
 .../proton/cpp/api/pages.html                   |     1 +
 .../cpp/api/pn__unique__ptr_8hpp_source.html    |     2 +-
 .../proton/cpp/api/receiver_8hpp_source.html    |     2 +-
 .../proton/cpp/api/receiver__options_8hpp.html  |     1 +
 .../cpp/api/receiver__options_8hpp_source.html  |    10 +-
 .../cpp/api/reconnect__options_8hpp_source.html |     2 +-
 .../proton/cpp/api/returned_8hpp_source.html    |     2 +-
 .../proton/cpp/api/sasl_8hpp_source.html        |    15 +-
 .../proton/cpp/api/scalar_8hpp.html             |     1 +
 .../proton/cpp/api/scalar_8hpp_source.html      |    14 +-
 .../cpp/api/scalar__base_8hpp_source.html       |     3 +-
 .../cpp/api/scheduled_send_03_8cpp-example.html |     2 +-
 .../cpp/api/scheduled_send_8cpp-example.html    |     2 +-
 .../proton/cpp/api/search/all_0.js              |     2 +-
 .../proton/cpp/api/search/all_13.js             |     1 -
 .../proton/cpp/api/search/all_2.js              |     3 +-
 .../proton/cpp/api/search/all_3.js              |     2 +
 .../proton/cpp/api/search/all_9.js              |     2 +-
 .../proton/cpp/api/search/all_a.js              |     3 +-
 .../proton/cpp/api/search/all_b.js              |     4 +-
 .../proton/cpp/api/search/all_c.js              |    66 +-
 .../proton/cpp/api/search/all_d.js              |     2 +-
 .../proton/cpp/api/search/all_e.js              |     2 +-
 .../proton/cpp/api/search/all_f.js              |     5 +-
 .../proton/cpp/api/search/classes_8.js          |     5 +-
 .../proton/cpp/api/search/classes_9.js          |    19 +-
 .../proton/cpp/api/search/classes_a.js          |    23 +-
 .../proton/cpp/api/search/classes_b.js          |    11 +-
 .../proton/cpp/api/search/classes_c.js          |     4 +-
 .../proton/cpp/api/search/classes_d.js          |     3 +-
 .../proton/cpp/api/search/classes_e.html        |    26 +
 .../proton/cpp/api/search/classes_e.js          |     4 +
 .../proton/cpp/api/search/files_8.js            |     3 +-
 .../proton/cpp/api/search/functions_0.js        |     2 +-
 .../proton/cpp/api/search/functions_13.js       |     1 -
 .../proton/cpp/api/search/functions_2.js        |     3 +-
 .../proton/cpp/api/search/functions_3.js        |     1 +
 .../proton/cpp/api/search/functions_9.js        |     2 +-
 .../proton/cpp/api/search/functions_a.js        |     2 +-
 .../proton/cpp/api/search/functions_b.js        |     5 +-
 .../proton/cpp/api/search/functions_c.js        |    66 +-
 .../proton/cpp/api/search/functions_d.js        |     2 +-
 .../proton/cpp/api/search/functions_e.js        |     2 +-
 .../proton/cpp/api/search/functions_f.js        |     5 +-
 .../proton/cpp/api/search/pages_1.js            |     3 +-
 .../proton/cpp/api/search/pages_2.js            |     3 +-
 .../proton/cpp/api/search/pages_3.js            |     2 +-
 .../proton/cpp/api/search/pages_4.js            |     2 +-
 .../proton/cpp/api/search/pages_5.html          |    26 +
 .../proton/cpp/api/search/pages_5.js            |     4 +
 .../proton/cpp/api/search/searchdata.js         |     4 +-
 .../proton/cpp/api/search/variables_4.js        |     1 +
 .../proton/cpp/api/sender_8hpp_source.html      |     2 +-
 .../proton/cpp/api/sender__options_8hpp.html    |     1 +
 .../cpp/api/sender__options_8hpp_source.html    |     8 +-
 .../proton/cpp/api/server_8cpp-example.html     |     2 +-
 .../cpp/api/server_direct_8cpp-example.html     |     2 +-
 .../cpp/api/service_bus_8cpp-example.html       |     2 +-
 .../proton/cpp/api/session_8hpp_source.html     |     8 +-
 .../cpp/api/session__options_8hpp_source.html   |     2 +-
 .../cpp/api/simple_recv_8cpp-example.html       |     2 +-
 .../cpp/api/simple_send_8cpp-example.html       |     2 +-
 .../proton/cpp/api/source_8hpp_source.html      |     2 +-
 .../cpp/api/source__options_8hpp_source.html    |    13 +-
 .../proton/cpp/api/ssl_8hpp.html                |     1 +
 .../proton/cpp/api/ssl_8hpp_source.html         |    24 +-
 .../proton/cpp/api/target_8hpp_source.html      |     2 +-
 .../cpp/api/target__options_8hpp_source.html    |    11 +-
 .../proton/cpp/api/terminus_8hpp.html           |     1 +
 .../proton/cpp/api/terminus_8hpp_source.html    |     6 +-
 .../proton/cpp/api/thread__safe_8hpp.html       |     4 +-
 .../cpp/api/thread__safe_8hpp_source.html       |     2 +-
 .../proton/cpp/api/tracker_8hpp_source.html     |     2 +-
 .../proton/cpp/api/transfer_8hpp_source.html    |     4 +-
 .../proton/cpp/api/transport_8hpp_source.html   |     2 +-
 .../proton/cpp/api/tutorial_page.html           |    59 +-
 .../cpp/api/type__traits_8hpp_source.html       |     2 +-
 .../proton/cpp/api/types_8hpp.html              |     2 +-
 .../proton/cpp/api/types_8hpp_source.html       |     4 +-
 .../proton/cpp/api/types__fwd_8hpp.html         |     1 -
 .../proton/cpp/api/types__fwd_8hpp_source.html  |     2 +-
 .../proton/cpp/api/url_8hpp_source.html         |    23 +-
 .../proton/cpp/api/uuid_8hpp.html               |     2 +-
 .../proton/cpp/api/uuid_8hpp_source.html        |     2 +-
 .../proton/cpp/api/value_8hpp_source.html       |     7 +-
 .../proton/cpp/api/work__queue_8hpp.html        |    26 +-
 .../proton/cpp/api/work__queue_8hpp.js          |     8 -
 .../proton/cpp/api/work__queue_8hpp_source.html |    14 +-
 .../proton/cpp/examples/broker.cpp              |    48 +-
 .../proton/cpp/examples/broker.cpp.html.in      |    48 +-
 .../proton/cpp/examples/colour_send.cpp         |   116 +
 .../proton/cpp/examples/colour_send.cpp.html.in |   100 +
 .../proton/cpp/examples/direct_recv.cpp         |    11 +-
 .../proton/cpp/examples/direct_recv.cpp.html.in |    11 +-
 .../proton/cpp/examples/direct_send.cpp         |    11 +-
 .../proton/cpp/examples/direct_send.cpp.html.in |    11 +-
 .../proton/cpp/examples/encode_decode.cpp       |     2 +-
 .../cpp/examples/encode_decode.cpp.html.in      |     2 +-
 .../proton/cpp/examples/flow_control.cpp        |    30 +-
 .../cpp/examples/flow_control.cpp.html.in       |    30 +-
 .../proton/cpp/examples/helloworld.cpp          |    19 +-
 .../proton/cpp/examples/helloworld.cpp.html.in  |    19 +-
 .../proton/cpp/examples/helloworld_direct.cpp   |    81 -
 .../cpp/examples/helloworld_direct.cpp.html.in  |    65 -
 .../proton/cpp/examples/index.md                |     7 +-
 .../cpp/examples/multithreaded_client.cpp       |     4 +-
 .../examples/multithreaded_client.cpp.html.in   |     4 +-
 .../multithreaded_client_flow_control.cpp       |    11 +-
 ...ultithreaded_client_flow_control.cpp.html.in |    11 +-
 .../proton/cpp/examples/queue_browser.cpp       |    34 +-
 .../cpp/examples/queue_browser.cpp.html.in      |    34 +-
 .../proton/cpp/examples/reconnect_client.cpp    |     3 +-
 .../cpp/examples/reconnect_client.cpp.html.in   |     3 +-
 .../proton/cpp/examples/scheduled_send.cpp      |     1 +
 .../cpp/examples/scheduled_send.cpp.html.in     |     1 +
 .../proton/cpp/examples/scheduled_send_03.cpp   |     8 +-
 .../cpp/examples/scheduled_send_03.cpp.html.in  |     8 +-
 .../proton/cpp/examples/selected_recv.cpp       |    19 +-
 .../cpp/examples/selected_recv.cpp.html.in      |    19 +-
 .../proton/cpp/examples/server.cpp              |    53 +-
 .../proton/cpp/examples/server.cpp.html.in      |    55 +-
 .../proton/cpp/examples/server_direct.cpp       |    11 +-
 .../cpp/examples/server_direct.cpp.html.in      |    11 +-
 .../proton/cpp/examples/service_bus.cpp         |    22 +-
 .../proton/cpp/examples/service_bus.cpp.html.in |    22 +-
 .../proton/cpp/examples/simple_connect.cpp      |   111 +
 .../cpp/examples/simple_connect.cpp.html.in     |    95 +
 .../proton/cpp/examples/simple_recv.cpp         |     1 -
 .../proton/cpp/examples/simple_recv.cpp.html.in |     1 -
 .../proton/cpp/examples/ssl.cpp                 |    49 +-
 .../proton/cpp/examples/ssl.cpp.html.in         |    49 +-
 .../proton/cpp/examples/ssl_client_cert.cpp     |    31 +-
 .../cpp/examples/ssl_client_cert.cpp.html.in    |    31 +-
 .../proton/python/api/api-objects.txt           |    73 +-
 .../proton/python/api/class-tree.html           |    19 +-
 .../proton/python/api/identifier-index.html     |  1402 ++-
 .../proton/python/api/proton-module.html        |    39 +-
 .../proton/python/api/proton-pysrc.html         |  8611 +++++++-------
 .../python/api/proton.Delivery-class.html       |    59 +-
 .../proton/python/api/proton.Handler-class.html |     2 +-
 .../python/api/proton.Interrupt-class.html      |     2 +-
 .../proton/python/api/proton.Link-class.html    |     4 +-
 .../api/proton.MessageException-class.html      |     2 +-
 .../python/api/proton.Messenger-class.html      |  1591 ---
 .../api/proton.MessengerException-class.html    |   165 -
 .../api/proton.ProtonException-class.html       |     2 +-
 .../proton/python/api/proton.Url-class.html     |     5 +-
 .../python/api/proton._compat-module.html       |    17 +
 .../proton/python/api/proton._compat-pysrc.html |    75 +-
 .../python/api/proton.handlers-pysrc.html       |  1377 ++-
 .../api/proton.handlers.Acking-class.html       |    26 +-
 ...n.handlers.IncomingMessageHandler-class.html |    19 +-
 .../proton.handlers.MessagingHandler-class.html |     6 +-
 ...n.handlers.OutgoingMessageHandler-class.html |     2 +-
 ...ndlers.TransactionalClientHandler-class.html |     2 +
 .../python/api/proton.reactor-module.html       |     2 +-
 .../proton/python/api/proton.reactor-pysrc.html |  1368 ++-
 .../api/proton.reactor.Container-class.html     |    34 +-
 .../api/proton.reactor.EventInjector-class.html |     2 +-
 .../api/proton.reactor.Reactor-class.html       |     2 +-
 .../proton/python/api/proton.utils-module.html  |     2 +-
 .../proton/python/api/proton.utils-pysrc.html   |  1199 +-
 .../python/api/proton.utils.Fetcher-class.html  |     2 +-
 .../proton.utils.SyncRequestResponse-class.html |     5 +-
 .../python/api/proton.wrapper-module.html       |     2 +-
 .../proton/python/api/proton.wrapper-pysrc.html |   147 +-
 .../proton/python/api/redirect.html             |     2 +-
 .../proton/python/api/toc-everything.html       |    10 +-
 .../proton/python/api/toc-proton-module.html    |    10 +-
 .../proton/python/book/.buildinfo               |     4 +
 .../proton/python/book/_sources/index.rst.txt   |    11 +
 .../python/book/_sources/overview.rst.txt       |   160 +
 .../python/book/_sources/tutorial.rst.txt       |   301 +
 .../proton/python/book/_static/ajax-loader.gif  |   Bin 0 -> 673 bytes
 .../proton/python/book/_static/basic.css        |   632 ++
 .../python/book/_static/comment-bright.png      |   Bin 0 -> 756 bytes
 .../python/book/_static/comment-close.png       |   Bin 0 -> 829 bytes
 .../proton/python/book/_static/comment.png      |   Bin 0 -> 641 bytes
 .../proton/python/book/_static/contents.png     |   Bin 0 -> 107 bytes
 .../proton/python/book/_static/doctools.js      |   287 +
 .../proton/python/book/_static/down-pressed.png |   Bin 0 -> 222 bytes
 .../proton/python/book/_static/down.png         |   Bin 0 -> 202 bytes
 .../proton/python/book/_static/file.png         |   Bin 0 -> 286 bytes
 .../proton/python/book/_static/jquery-3.1.0.js  | 10074 +++++++++++++++++
 .../proton/python/book/_static/jquery.js        |     4 +
 .../proton/python/book/_static/minus.png        |   Bin 0 -> 90 bytes
 .../proton/python/book/_static/navigation.png   |   Bin 0 -> 120 bytes
 .../proton/python/book/_static/plus.png         |   Bin 0 -> 90 bytes
 .../proton/python/book/_static/pygments.css     |    69 +
 .../proton/python/book/_static/searchtools.js   |   758 ++
 .../proton/python/book/_static/sphinxdoc.css    |   345 +
 .../python/book/_static/underscore-1.3.1.js     |   999 ++
 .../proton/python/book/_static/underscore.js    |    31 +
 .../proton/python/book/_static/up-pressed.png   |   Bin 0 -> 214 bytes
 .../proton/python/book/_static/up.png           |   Bin 0 -> 203 bytes
 .../proton/python/book/_static/websupport.js    |   808 ++
 .../proton/python/book/conf.py                  |   242 -
 .../proton/python/book/genindex.html            |   482 +
 .../proton/python/book/index.html               |   119 +
 .../proton/python/book/index.rst                |    11 -
 .../proton/python/book/objects.inv              |    10 +
 .../proton/python/book/overview.html            |   939 ++
 .../proton/python/book/overview.rst             |   160 -
 .../proton/python/book/search.html              |   101 +
 .../proton/python/book/searchindex.js           |     1 +
 .../proton/python/book/tutorial.html            |  1148 ++
 .../proton/python/book/tutorial.rst             |   301 -
 .../proton/python/examples/colour_send.py       |    68 +
 .../python/examples/colour_send.py.html.in      |    53 +
 .../proton/python/examples/index.md             |     5 +-
 .../proton/python/examples/selected_recv.py     |    26 +-
 .../python/examples/selected_recv.py.html.in    |    26 +-
 .../proton/python/examples/sync_client.py       |     2 +-
 .../python/examples/sync_client.py.html.in      |     2 +-
 .../proton/python/examples/test_examples.py     |    17 +
 .../python/examples/test_examples.py.html.in    |    17 +
 .../proton/ruby/api/Qpid.html                   |   128 +
 .../proton/ruby/api/Qpid/Proton.html            |   349 +
 .../ruby/api/Qpid/Proton/AbortedError.html      |   143 +
 .../ruby/api/Qpid/Proton/ArgumentError.html     |   143 +
 .../ruby/api/Qpid/Proton/AttributeError.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/Condition.html  |   827 ++
 .../proton/ruby/api/Qpid/Proton/Connection.html |  3001 +++++
 .../ruby/api/Qpid/Proton/ConnectionDriver.html  |  1663 +++
 .../proton/ruby/api/Qpid/Proton/Container.html  |  2203 ++++
 .../Qpid/Proton/Container/ConnectionTask.html   |   441 +
 .../api/Qpid/Proton/Container/ListenTask.html   |  1017 ++
 .../api/Qpid/Proton/Container/SelectWaker.html  |   482 +
 .../api/Qpid/Proton/Container/StoppedError.html |   237 +
 .../proton/ruby/api/Qpid/Proton/Delivery.html   |  1009 ++
 .../ruby/api/Qpid/Proton/Disposition.html       |   899 ++
 .../proton/ruby/api/Qpid/Proton/EOSError.html   |   143 +
 .../proton/ruby/api/Qpid/Proton/Endpoint.html   |  1082 ++
 .../proton/ruby/api/Qpid/Proton/Event.html      |  1429 +++
 .../proton/ruby/api/Qpid/Proton/Handler.html    |   213 +
 .../ruby/api/Qpid/Proton/Handler/Adapter.html   |   497 +
 .../api/Qpid/Proton/Handler/ArrayHandler.html   |   602 +
 .../Qpid/Proton/Handler/MessagingAdapter.html   |  1104 ++
 .../Qpid/Proton/Handler/MessagingHandler.html   |   482 +
 .../Proton/Handler/ReactorMessagingAdapter.html |  1139 ++
 .../ruby/api/Qpid/Proton/HandlerDriver.html     |   576 +
 .../ruby/api/Qpid/Proton/InProgressError.html   |   141 +
 .../ruby/api/Qpid/Proton/InterruptedError.html  |   143 +
 .../proton/ruby/api/Qpid/Proton/Link.html       |  1795 +++
 .../proton/ruby/api/Qpid/Proton/LinkError.html  |   143 +
 .../proton/ruby/api/Qpid/Proton/Listener.html   |   649 ++
 .../ruby/api/Qpid/Proton/Listener/Handler.html  |   598 +
 .../proton/ruby/api/Qpid/Proton/Message.html    |  4278 +++++++
 .../ruby/api/Qpid/Proton/MessagingHandler.html  |   246 +
 .../ruby/api/Qpid/Proton/OverflowError.html     |   143 +
 .../ruby/api/Qpid/Proton/ProtonError.html       |   139 +
 .../proton/ruby/api/Qpid/Proton/Reactor.html    |   124 +
 .../ruby/api/Qpid/Proton/Reactor/Container.html |   551 +
 .../proton/ruby/api/Qpid/Proton/Receiver.html   |   881 ++
 .../proton/ruby/api/Qpid/Proton/Reject.html     |   143 +
 .../proton/ruby/api/Qpid/Proton/Release.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/SASL.html       |   603 +
 .../proton/ruby/api/Qpid/Proton/SASLError.html  |   151 +
 .../proton/ruby/api/Qpid/Proton/SSL.html        |   700 ++
 .../proton/ruby/api/Qpid/Proton/SSLDomain.html  |   721 ++
 .../proton/ruby/api/Qpid/Proton/SSLError.html   |   153 +
 .../api/Qpid/Proton/SSLUnavailableError.html    |   157 +
 .../proton/ruby/api/Qpid/Proton/Sender.html     |   874 ++
 .../proton/ruby/api/Qpid/Proton/Session.html    |  1039 ++
 .../ruby/api/Qpid/Proton/SessionError.html      |   143 +
 .../proton/ruby/api/Qpid/Proton/StateError.html |   148 +
 .../ruby/api/Qpid/Proton/StopAutoResponse.html  |   144 +
 .../ruby/api/Qpid/Proton/StoppedError.html      |   155 +
 .../proton/ruby/api/Qpid/Proton/Terminus.html   |  1207 ++
 .../ruby/api/Qpid/Proton/TimeoutError.html      |   143 +
 .../proton/ruby/api/Qpid/Proton/Tracker.html    |   452 +
 .../proton/ruby/api/Qpid/Proton/Transfer.html   |  1307 +++
 .../ruby/api/Qpid/Proton/Transfer/State.html    |   209 +
 .../proton/ruby/api/Qpid/Proton/Transport.html  |  1957 ++++
 .../ruby/api/Qpid/Proton/TransportError.html    |   147 +
 .../proton/ruby/api/Qpid/Proton/Types.html      |   481 +
 .../ruby/api/Qpid/Proton/Types/ArrayHeader.html |   502 +
 .../api/Qpid/Proton/Types/BinaryString.html     |   136 +
 .../ruby/api/Qpid/Proton/Types/Described.html   |   133 +
 .../proton/ruby/api/Qpid/Proton/Types/Type.html |   533 +
 .../ruby/api/Qpid/Proton/Types/UTFString.html   |   226 +
 .../api/Qpid/Proton/Types/UniformArray.html     |   685 ++
 .../proton/ruby/api/Qpid/Proton/URL.html        |   854 ++
 .../ruby/api/Qpid/Proton/UnderflowError.html    |   143 +
 .../proton/ruby/api/Qpid/Proton/Util.html       |   132 +
 .../proton/ruby/api/Qpid/Proton/WorkQueue.html  |   439 +
 .../api/Qpid/Proton/WorkQueue/StoppedError.html |   237 +
 .../proton/ruby/api/_index.html                 |   731 ++
 .../proton/ruby/api/_transom_ignore_pages       |     0
 .../proton/ruby/api/class_list.html             |    51 +
 .../proton/ruby/api/css/common.css              |     1 +
 .../proton/ruby/api/css/full_list.css           |    58 +
 .../proton/ruby/api/css/style.css               |   492 +
 .../proton/ruby/api/file.README.html            |   229 +
 .../proton/ruby/api/file_list.html              |    56 +
 .../proton/ruby/api/frames.html                 |    17 +
 .../proton/ruby/api/index.html                  |   229 +
 .../proton/ruby/api/js/app.js                   |   243 +
 .../proton/ruby/api/js/full_list.js             |   216 +
 .../proton/ruby/api/js/jquery.js                |     4 +
 .../proton/ruby/api/method_list.html            |  3091 +++++
 .../proton/ruby/examples/broker.rb              |   174 +
 .../proton/ruby/examples/broker.rb.html.in      |   160 +
 .../proton/ruby/examples/client.rb              |    79 +
 .../proton/ruby/examples/client.rb.html.in      |    65 +
 .../proton/ruby/examples/direct_recv.rb         |    61 +
 .../proton/ruby/examples/direct_recv.rb.html.in |    46 +
 .../proton/ruby/examples/direct_send.rb         |    67 +
 .../proton/ruby/examples/direct_send.rb.html.in |    53 +
 .../proton/ruby/examples/example_test.rb        |   109 +
 .../ruby/examples/example_test.rb.html.in       |    94 +
 .../proton/ruby/examples/helloworld.rb          |    57 +
 .../proton/ruby/examples/helloworld.rb.html.in  |    43 +
 .../proton/ruby/examples/index.md               |    20 +
 .../proton/ruby/examples/server.rb              |    70 +
 .../proton/ruby/examples/server.rb.html.in      |    56 +
 .../proton/ruby/examples/simple_recv.rb         |    57 +
 .../proton/ruby/examples/simple_recv.rb.html.in |    42 +
 .../proton/ruby/examples/simple_send.rb         |    63 +
 .../proton/ruby/examples/simple_send.rb.html.in |    49 +
 .../proton/ruby/examples/ssl_send.rb            |    70 +
 .../proton/ruby/examples/ssl_send.rb.html.in    |    56 +
 1168 files changed, 163890 insertions(+), 28905 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/index.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/index.html b/content/releases/qpid-proton-master/index.html
index f77e206..9618191 100644
--- a/content/releases/qpid-proton-master/index.html
+++ b/content/releases/qpid-proton-master/index.html
@@ -124,7 +124,7 @@ https://github.com/apache/qpid-proton/blob/go1{/dir}/{file}#L{line}"/>
 smoother experience, see the <a href="/releases/qpid-proton-0.22.0/index.html">current stable
 release</a>.</p>
 
-<p>This content was generated at 16:18  on Tuesday, 12 September 2017.</p>
+<p>This content was generated at 06:28  on Tuesday, 01 May 2018.</p>
 
 </div>
 
@@ -135,13 +135,15 @@ release</a>.</p>
 <ul>
 <li><a href="proton/c/api/files.html">C API reference</a></li>
 <li><a href="proton/cpp/api/index.html">C++ introduction</a></li>
-<li><a href="proton/cpp/api/tutorial.html">C++ tutorial</a></li>
+<li><a href="proton/cpp/api/tutorial_page.html">C++ tutorial</a></li>
 <li><a href="proton/cpp/examples/index.html">C++ examples</a></li>
 <li><a href="proton/cpp/api/annotated.html">C++ API reference</a></li>
 <li><a href="proton/python/book/overview.html">Python overview</a></li>
 <li><a href="proton/python/book/tutorial.html">Python tutorial</a></li>
 <li><a href="proton/python/examples/index.html">Python examples</a></li>
 <li><a href="proton/python/api/index.html">Python API reference</a></li>
+<li><a href="proton/ruby/examples/index.html">Ruby examples</a></li>
+<li><a href="proton/ruby/api/index.html">Ruby API reference</a></li>
 <li><a href="https://git-wip-us.apache.org/repos/asf?p=qpid-proton.git;a=blob;f=INSTALL.md;hb=master">Installing Qpid Proton</a></li>
 </ul>
 

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/annotated.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/annotated.html b/content/releases/qpid-proton-master/proton/c/api/annotated.html
index d078197..0946b03 100755
--- a/content/releases/qpid-proton-master/proton/c/api/annotated.html
+++ b/content/releases/qpid-proton-master/proton/c/api/annotated.html
@@ -95,7 +95,7 @@ $(document).ready(function(){initNavTree('annotated.html','');});
 <div class="contents">
 <div class="textblock">Here are the classes, structs, unions and interfaces with brief descriptions:</div><div class="directory">
 <table class="directory">
-<tr id="row_0_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="group__api__types.html#structpn__atom__t" target="_self">pn_atom_t</a></td><td class="desc">A descriminated union that holds any scalar AMQP value </td></tr>
+<tr id="row_0_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="group__api__types.html#structpn__atom__t" target="_self">pn_atom_t</a></td><td class="desc">A discriminated union that holds any scalar AMQP value </td></tr>
 <tr id="row_1_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="group__api__types.html#structpn__bytes__t" target="_self">pn_bytes_t</a></td><td class="desc">A const byte buffer </td></tr>
 <tr id="row_2_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="group__connection__driver.html#structpn__connection__driver__t" target="_self">pn_connection_driver_t</a></td><td class="desc">The elements needed to drive AMQP IO and events </td></tr>
 <tr id="row_3_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="group__amqp__types.html#structpn__decimal128__t" target="_self">pn_decimal128_t</a></td><td class="desc">A 128-bit decimal floating-point number </td></tr>


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


[24/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/transport_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/transport_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/transport_8h_source.html
index 4646471..1096764 100755
--- a/content/releases/qpid-proton-master/proton/c/api/transport_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/transport_8h_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('transport_8h_source.html','');});
 <div class="title">transport.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="transport_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TRANSPORT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TRANSPORT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor licen
 se agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span
  class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the<
 /span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="l
 ineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="group__transport.html#ga46957
 88da8491f0c7104bfe36634ff94">   57</a></span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga4695788da8491f0c7104bfe36634ff94">pn_trace_t</a>;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno"><a class="line" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">   62</a></span>&#160;<span class="keyword">typedef</span> void (*<a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a>)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *message);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno"><a class="line" href="group__transport.h
 tml#gae8f32e46e94953bab10bee530eee9044">   67</a></span>&#160;<span class="preprocessor">#define PN_TRACE_OFF (0)</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno"><a class="line" href="group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8">   72</a></span>&#160;<span class="preprocessor">#define PN_TRACE_RAW (1)</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno"><a class="line" href="group__transport.html#gab8e04b4c128379ff27e6b801c0bce494">   77</a></span>&#160;<span class="preprocessor">#define PN_TRACE_FRM (2)</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno"><a class="line" href="group__transport.html#ga7065ad65f95c995a24e416edc95aead4">   83</a></span>&#160;<span
  class="preprocessor">#define PN_TRACE_DRV (4)</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno"><a class="line" href="group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688">   88</a></span>&#160;<span class="preprocessor">#define PN_TRACE_EVT (8)</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *<a class="code" href="group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77">pn_transport</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a c
 lass="code" href="group__transport.html#gac5bebd26c0942bc17d7fad36577110f8">pn_transport_set_server</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga6ab28051242631d9bea4814e8670ab90">pn_transport_free</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58">pn_transport_get_user
 </a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga285b4cced59c665ae178adf26128d3fc">pn_transport_require_auth</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">bool</span> required);</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d">pn_transport_is_authenticated</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f
 3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34">pn_transport_require_encryption</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">bool</span> required);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga737021ca419e948932071aad2ad38c5b">pn_transport_is_encrypted</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line">
 <a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00220"></a><span class="lineno">  220</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00221">
 </a><span class="lineno">  221</span>&#160;</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">pn_transport_bind</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50">pn_transport_unbind</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00235"></a><span class="lineno">
   235</span>&#160;</div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56">pn_transport_trace</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, pn_trace_t trace);</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7">pn_transport_set_tracer</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> tracer);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</spa
 n>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> <a class="code" href="group__transport.html#ga30d129d04a387ea34515c1641b83521b">pn_transport_get_tracer</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00297"></a><span class="l
 ineno">  297</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;</div><div class="line"><a name="l00305"></a><span class="lineno">  305</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__transport.html#gabdd6d56837a028097b1676350d65a864">pn_transport_attachments</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00306"></a><span class="lineno">  306</span>&#160;</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__
 transport.html#gad603e8d72578bcedd2d9235f74f28f37">pn_transport_log</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *message);</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;</div><div class="line"><a name="l00333"></a><span class="lineno">  333</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f">pn_transport_vlogf</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list ap);</div><div class="line"><a name="l00334"></a><span class="lineno">  334</span>&#160;</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;PN_EXTERN <span class="keywordtype">void</
 span> <a class="code" href="group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84">pn_transport_logf</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00348"></a><span class="lineno">  348</span>&#160;</div><div class="line"><a name="l00361"></a><span class="lineno">  361</span>&#160;PN_EXTERN uint16_t <a class="code" href="group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052">pn_transport_get_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00362"></a><span class="lineno">  362</span>&#160;</div><div class="line"><a name="l00382"></a><span class="lineno">  382</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga8f080d7fb1e7fea2c93391
 d0b8f59773">pn_transport_set_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, uint16_t channel_max);</div><div class="line"><a name="l00383"></a><span class="lineno">  383</span>&#160;</div><div class="line"><a name="l00392"></a><span class="lineno">  392</span>&#160;PN_EXTERN uint16_t <a class="code" href="group__transport.html#gaff7c08aeb92596ad9d269468d1557647">pn_transport_remote_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00393"></a><span class="lineno">  393</span>&#160;</div><div class="line"><a name="l00402"></a><span class="lineno">  402</span>&#160;PN_EXTERN uint32_t <a class="code" href="group__transport.html#ga46552ed46e59de6530d2eee03707a51b">pn_transport_get_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transpo
 rt);</div><div class="line"><a name="l00403"></a><span class="lineno">  403</span>&#160;</div><div class="line"><a name="l00412"></a><span class="lineno">  412</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga51573625b6940884fed214b615f42e0f">pn_transport_set_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, uint32_t size);</div><div class="line"><a name="l00413"></a><span class="lineno">  413</span>&#160;</div><div class="line"><a name="l00422"></a><span class="lineno">  422</span>&#160;PN_EXTERN uint32_t <a class="code" href="group__transport.html#ga351823e18e043576078f361d7dfe1cce">pn_transport_get_remote_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00423"></a><span class="lineno">  423</span>&#160;</div><div class="line"><a name="l00434"
 ></a><span class="lineno">  434</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="group__transport.html#ga6980396c3d890b86656167c3a063eee7">pn_transport_get_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00435"></a><span class="lineno">  435</span>&#160;</div><div class="line"><a name="l00446"></a><span class="lineno">  446</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gafb1c98602d17524eb40e48bf610362d7">pn_transport_set_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> timeout);</div><div class="line"><a name="l00447"></a><span class="lineno">  447</s
 pan>&#160;</div><div class="line"><a name="l00458"></a><span class="lineno">  458</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5">pn_transport_get_remote_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00459"></a><span class="lineno">  459</span>&#160;</div><div class="line"><a name="l00463"></a><span class="lineno">  463</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> available);</div><div class="line"><a name=
 "l00464"></a><span class="lineno">  464</span>&#160;</div><div class="line"><a name="l00468"></a><span class="lineno">  468</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00469"></a><span class="lineno">  469</span>&#160;</div><div class="line"><a name="l00484"></a><span class="lineno">  484</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">pn_transport_capacity</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00485"></a><span class="lineno">  485</span>&#160;</div><div class="line"><a name="l00496"></a><spa
 n class="lineno">  496</span>&#160;PN_EXTERN <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85">pn_transport_tail</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00497"></a><span class="lineno">  497</span>&#160;</div><div class="line"><a name="l00513"></a><span class="lineno">  513</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b">pn_transport_push</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *src, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00514"></a><span class="lineno">  514</span>&#160;</div><div class="line"><a name="l00528"></a><span class="lineno">  528</span>&#160;PN_EXTER
 N <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91">pn_transport_process</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00529"></a><span class="lineno">  529</span>&#160;</div><div class="line"><a name="l00538"></a><span class="lineno">  538</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289">pn_transport_close_tail</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00539"></a><span class="lineno">  539</span>&#160;</div><div class="line"><a name="l00554"></a><span class="lineno">  554</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga81adf1fd6fa28054f2f80c424aa981
 22">pn_transport_pending</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00555"></a><span class="lineno">  555</span>&#160;</div><div class="line"><a name="l00568"></a><span class="lineno">  568</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga3ef8b0032b2a012c697e853e363338ea">pn_transport_head</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00569"></a><span class="lineno">  569</span>&#160;</div><div class="line"><a name="l00582"></a><span class="lineno">  582</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga09a0d15514ca9a14eb40f12425a52797">pn_transport_peek</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *tran
 sport, <span class="keywordtype">char</span> *dst, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00583"></a><span class="lineno">  583</span>&#160;</div><div class="line"><a name="l00595"></a><span class="lineno">  595</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9">pn_transport_pop</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00596"></a><span class="lineno">  596</span>&#160;</div><div class="line"><a name="l00605"></a><span class="lineno">  605</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072">pn_transport_close_head</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *tra
 nsport);</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;</div><div class="line"><a name="l00613"></a><span class="lineno">  613</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef">pn_transport_quiesced</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00614"></a><span class="lineno">  614</span>&#160;</div><div class="line"><a name="l00618"></a><span class="lineno">  618</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga3eb018b426d168de8c8d9b3441be036c">pn_transport_head_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00619"></a><span class="lineno">  619</span>&#160;</div><div class="line"><a name="l00
 623"></a><span class="lineno">  623</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694">pn_transport_tail_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00624"></a><span class="lineno">  624</span>&#160;</div><div class="line"><a name="l00628"></a><span class="lineno">  628</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga55c589d9b3e69057b130036c3c2173df">pn_transport_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00629"></a><span class="lineno">  629</span>&#160;</div><div class="line"><a name="l00645"></a><span class="lineno">  645</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e0
 0e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9">pn_transport_tick</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> now);</div><div class="line"><a name="l00646"></a><span class="lineno">  646</span>&#160;</div><div class="line"><a name="l00653"></a><span class="lineno">  653</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__transport.html#ga3887e8d8c60d06df9978947edaf4d461">pn_transport_get_frames_output</a>(<span class="keyword">const</span> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00654"></a><span class="lineno">  654</span>&#160;</div><div class="line"><a name="l00661"></a><span class="lineno">  661</span>&#160;PN_EXTERN uint64_t <a class="code
 " href="group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61">pn_transport_get_frames_input</a>(<span class="keyword">const</span> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00662"></a><span class="lineno">  662</span>&#160;</div><div class="line"><a name="l00670"></a><span class="lineno">  670</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf">pn_transport_connection</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00671"></a><span class="lineno">  671</span>&#160;</div><div class="line"><a name="l00672"></a><span class="lineno">  672</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name=
 "l00673"></a><span class="lineno">  673</span>&#160;}</div><div class="line"><a name="l00674"></a><span class="lineno">  674</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00675"></a><span class="lineno">  675</span>&#160;</div><div class="line"><a name="l00680"></a><span class="lineno">  680</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* transport.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:147</div></div>
+<a href="transport_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TRANSPORT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TRANSPORT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor licen
 se agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span
  class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the<
 /span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="l
 ineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="group__transport.html#ga46957
 88da8491f0c7104bfe36634ff94">   57</a></span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga4695788da8491f0c7104bfe36634ff94">pn_trace_t</a>;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno"><a class="line" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">   62</a></span>&#160;<span class="keyword">typedef</span> void (*<a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a>)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *message);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno"><a class="line" href="group__transport.h
 tml#gae8f32e46e94953bab10bee530eee9044">   67</a></span>&#160;<span class="preprocessor">#define PN_TRACE_OFF (0)</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno"><a class="line" href="group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8">   72</a></span>&#160;<span class="preprocessor">#define PN_TRACE_RAW (1)</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno"><a class="line" href="group__transport.html#gab8e04b4c128379ff27e6b801c0bce494">   77</a></span>&#160;<span class="preprocessor">#define PN_TRACE_FRM (2)</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno"><a class="line" href="group__transport.html#ga7065ad65f95c995a24e416edc95aead4">   83</a></span>&#160;<span
  class="preprocessor">#define PN_TRACE_DRV (4)</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno"><a class="line" href="group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688">   88</a></span>&#160;<span class="preprocessor">#define PN_TRACE_EVT (8)</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *<a class="code" href="group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77">pn_transport</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a c
 lass="code" href="group__transport.html#gac5bebd26c0942bc17d7fad36577110f8">pn_transport_set_server</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga6ab28051242631d9bea4814e8670ab90">pn_transport_free</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58">pn_transport_get_user
 </a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga285b4cced59c665ae178adf26128d3fc">pn_transport_require_auth</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">bool</span> required);</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d">pn_transport_is_authenticated</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f
 3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34">pn_transport_require_encryption</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">bool</span> required);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga737021ca419e948932071aad2ad38c5b">pn_transport_is_encrypted</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line">
 <a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00220"></a><span class="lineno">  220</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00221">
 </a><span class="lineno">  221</span>&#160;</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">pn_transport_bind</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50">pn_transport_unbind</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00235"></a><span class="lineno">
   235</span>&#160;</div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56">pn_transport_trace</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, pn_trace_t trace);</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7">pn_transport_set_tracer</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> tracer);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</spa
 n>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> <a class="code" href="group__transport.html#ga30d129d04a387ea34515c1641b83521b">pn_transport_get_tracer</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00297"></a><span class="l
 ineno">  297</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;</div><div class="line"><a name="l00305"></a><span class="lineno">  305</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__transport.html#gabdd6d56837a028097b1676350d65a864">pn_transport_attachments</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00306"></a><span class="lineno">  306</span>&#160;</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__
 transport.html#gad603e8d72578bcedd2d9235f74f28f37">pn_transport_log</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *message);</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;</div><div class="line"><a name="l00333"></a><span class="lineno">  333</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f">pn_transport_vlogf</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list ap);</div><div class="line"><a name="l00334"></a><span class="lineno">  334</span>&#160;</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;PN_EXTERN <span class="keywordtype">void</
 span> <a class="code" href="group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84">pn_transport_logf</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00348"></a><span class="lineno">  348</span>&#160;</div><div class="line"><a name="l00361"></a><span class="lineno">  361</span>&#160;PN_EXTERN uint16_t <a class="code" href="group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052">pn_transport_get_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00362"></a><span class="lineno">  362</span>&#160;</div><div class="line"><a name="l00382"></a><span class="lineno">  382</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga8f080d7fb1e7fea2c93391
 d0b8f59773">pn_transport_set_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, uint16_t channel_max);</div><div class="line"><a name="l00383"></a><span class="lineno">  383</span>&#160;</div><div class="line"><a name="l00392"></a><span class="lineno">  392</span>&#160;PN_EXTERN uint16_t <a class="code" href="group__transport.html#gaff7c08aeb92596ad9d269468d1557647">pn_transport_remote_channel_max</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00393"></a><span class="lineno">  393</span>&#160;</div><div class="line"><a name="l00402"></a><span class="lineno">  402</span>&#160;PN_EXTERN uint32_t <a class="code" href="group__transport.html#ga46552ed46e59de6530d2eee03707a51b">pn_transport_get_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transpo
 rt);</div><div class="line"><a name="l00403"></a><span class="lineno">  403</span>&#160;</div><div class="line"><a name="l00412"></a><span class="lineno">  412</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga51573625b6940884fed214b615f42e0f">pn_transport_set_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, uint32_t size);</div><div class="line"><a name="l00413"></a><span class="lineno">  413</span>&#160;</div><div class="line"><a name="l00422"></a><span class="lineno">  422</span>&#160;PN_EXTERN uint32_t <a class="code" href="group__transport.html#ga351823e18e043576078f361d7dfe1cce">pn_transport_get_remote_max_frame</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00423"></a><span class="lineno">  423</span>&#160;</div><div class="line"><a name="l00434"
 ></a><span class="lineno">  434</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="group__transport.html#ga6980396c3d890b86656167c3a063eee7">pn_transport_get_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00435"></a><span class="lineno">  435</span>&#160;</div><div class="line"><a name="l00446"></a><span class="lineno">  446</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#gafb1c98602d17524eb40e48bf610362d7">pn_transport_set_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> timeout);</div><div class="line"><a name="l00447"></a><span class="lineno">  447</s
 pan>&#160;</div><div class="line"><a name="l00458"></a><span class="lineno">  458</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5">pn_transport_get_remote_idle_timeout</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00459"></a><span class="lineno">  459</span>&#160;</div><div class="line"><a name="l00463"></a><span class="lineno">  463</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> available);</div><div class="line"><a name=
 "l00464"></a><span class="lineno">  464</span>&#160;</div><div class="line"><a name="l00468"></a><span class="lineno">  468</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00469"></a><span class="lineno">  469</span>&#160;</div><div class="line"><a name="l00484"></a><span class="lineno">  484</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">pn_transport_capacity</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00485"></a><span class="lineno">  485</span>&#160;</div><div class="line"><a name="l00496"></a><spa
 n class="lineno">  496</span>&#160;PN_EXTERN <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85">pn_transport_tail</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00497"></a><span class="lineno">  497</span>&#160;</div><div class="line"><a name="l00513"></a><span class="lineno">  513</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b">pn_transport_push</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *src, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00514"></a><span class="lineno">  514</span>&#160;</div><div class="line"><a name="l00528"></a><span class="lineno">  528</span>&#160;PN_EXTER
 N <span class="keywordtype">int</span> <a class="code" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91">pn_transport_process</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00529"></a><span class="lineno">  529</span>&#160;</div><div class="line"><a name="l00538"></a><span class="lineno">  538</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289">pn_transport_close_tail</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00539"></a><span class="lineno">  539</span>&#160;</div><div class="line"><a name="l00554"></a><span class="lineno">  554</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga81adf1fd6fa28054f2f80c424aa981
 22">pn_transport_pending</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00555"></a><span class="lineno">  555</span>&#160;</div><div class="line"><a name="l00568"></a><span class="lineno">  568</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__transport.html#ga3ef8b0032b2a012c697e853e363338ea">pn_transport_head</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00569"></a><span class="lineno">  569</span>&#160;</div><div class="line"><a name="l00582"></a><span class="lineno">  582</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__transport.html#ga09a0d15514ca9a14eb40f12425a52797">pn_transport_peek</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *tran
 sport, <span class="keywordtype">char</span> *dst, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00583"></a><span class="lineno">  583</span>&#160;</div><div class="line"><a name="l00595"></a><span class="lineno">  595</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9">pn_transport_pop</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00596"></a><span class="lineno">  596</span>&#160;</div><div class="line"><a name="l00605"></a><span class="lineno">  605</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072">pn_transport_close_head</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *tra
 nsport);</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;</div><div class="line"><a name="l00613"></a><span class="lineno">  613</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef">pn_transport_quiesced</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00614"></a><span class="lineno">  614</span>&#160;</div><div class="line"><a name="l00618"></a><span class="lineno">  618</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga3eb018b426d168de8c8d9b3441be036c">pn_transport_head_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00619"></a><span class="lineno">  619</span>&#160;</div><div class="line"><a name="l00
 623"></a><span class="lineno">  623</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694">pn_transport_tail_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00624"></a><span class="lineno">  624</span>&#160;</div><div class="line"><a name="l00628"></a><span class="lineno">  628</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__transport.html#ga55c589d9b3e69057b130036c3c2173df">pn_transport_closed</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00629"></a><span class="lineno">  629</span>&#160;</div><div class="line"><a name="l00645"></a><span class="lineno">  645</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e0
 0e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9">pn_transport_tick</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> now);</div><div class="line"><a name="l00646"></a><span class="lineno">  646</span>&#160;</div><div class="line"><a name="l00653"></a><span class="lineno">  653</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__transport.html#ga3887e8d8c60d06df9978947edaf4d461">pn_transport_get_frames_output</a>(<span class="keyword">const</span> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00654"></a><span class="lineno">  654</span>&#160;</div><div class="line"><a name="l00661"></a><span class="lineno">  661</span>&#160;PN_EXTERN uint64_t <a class="code
 " href="group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61">pn_transport_get_frames_input</a>(<span class="keyword">const</span> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00662"></a><span class="lineno">  662</span>&#160;</div><div class="line"><a name="l00670"></a><span class="lineno">  670</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf">pn_transport_connection</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00671"></a><span class="lineno">  671</span>&#160;</div><div class="line"><a name="l00672"></a><span class="lineno">  672</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name=
 "l00673"></a><span class="lineno">  673</span>&#160;}</div><div class="line"><a name="l00674"></a><span class="lineno">  674</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00675"></a><span class="lineno">  675</span>&#160;</div><div class="line"><a name="l00680"></a><span class="lineno">  680</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* transport.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:145</div></div>
 <div class="ttc" id="group__transport_html_gabdd6d56837a028097b1676350d65a864"><div class="ttname"><a href="group__transport.html#gabdd6d56837a028097b1676350d65a864">pn_transport_attachments</a></div><div class="ttdeci">pn_record_t * pn_transport_attachments(pn_transport_t *transport)</div><div class="ttdoc">Get the attachments that are associated with a transport object. </div></div>
 <div class="ttc" id="group__transport_html_gac773c1b9226783f36e2f2d4770e90e3f"><div class="ttname"><a href="group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f">pn_transport_vlogf</a></div><div class="ttdeci">void pn_transport_vlogf(pn_transport_t *transport, const char *fmt, va_list ap)</div><div class="ttdoc">Log a printf formatted message using a transport&amp;#39;s logging mechanism. </div></div>
 <div class="ttc" id="group__transport_html_gafb1c98602d17524eb40e48bf610362d7"><div class="ttname"><a href="group__transport.html#gafb1c98602d17524eb40e48bf610362d7">pn_transport_set_idle_timeout</a></div><div class="ttdeci">void pn_transport_set_idle_timeout(pn_transport_t *transport, pn_millis_t timeout)</div><div class="ttdoc">Set the idle timeout for a transport. </div></div>
@@ -101,18 +101,18 @@ $(document).ready(function(){initNavTree('transport_8h_source.html','');});
 <div class="ttc" id="group__transport_html_ga285b4cced59c665ae178adf26128d3fc"><div class="ttname"><a href="group__transport.html#ga285b4cced59c665ae178adf26128d3fc">pn_transport_require_auth</a></div><div class="ttdeci">void pn_transport_require_auth(pn_transport_t *transport, bool required)</div><div class="ttdoc">Set whether a non-authenticated transport connection is allowed. </div></div>
 <div class="ttc" id="group__transport_html_ga26cff9ffda93e2ffc8606e19eefe7f84"><div class="ttname"><a href="group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84">pn_transport_logf</a></div><div class="ttdeci">void pn_transport_logf(pn_transport_t *transport, const char *fmt,...)</div><div class="ttdoc">Log a printf formatted message using a transport&amp;#39;s logging mechanism. </div></div>
 <div class="ttc" id="group__transport_html_ga4a9e6c6b207c41647ff988b5ae090d85"><div class="ttname"><a href="group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85">pn_transport_tail</a></div><div class="ttdeci">char * pn_transport_tail(pn_transport_t *transport)</div><div class="ttdoc">Get the transport&amp;#39;s tail pointer. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__transport_html_ga09a0d15514ca9a14eb40f12425a52797"><div class="ttname"><a href="group__transport.html#ga09a0d15514ca9a14eb40f12425a52797">pn_transport_peek</a></div><div class="ttdeci">ssize_t pn_transport_peek(pn_transport_t *transport, char *dst, size_t size)</div><div class="ttdoc">Copies size bytes from the head of the transport to the dst pointer. </div></div>
 <div class="ttc" id="group__transport_html_ga3887e8d8c60d06df9978947edaf4d461"><div class="ttname"><a href="group__transport.html#ga3887e8d8c60d06df9978947edaf4d461">pn_transport_get_frames_output</a></div><div class="ttdeci">uint64_t pn_transport_get_frames_output(const pn_transport_t *transport)</div><div class="ttdoc">Get the number of frames output by a transport. </div></div>
 <div class="ttc" id="group__transport_html_gaa83f8c30fc0e7518c6ef214bb7b4ea56"><div class="ttname"><a href="group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56">pn_transport_trace</a></div><div class="ttdeci">void pn_transport_trace(pn_transport_t *transport, pn_trace_t trace)</div><div class="ttdoc">Update a transports trace flags. </div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
 <div class="ttc" id="group__transport_html_ga1a769e2e6c900c78c710407296cb4e13"><div class="ttname"><a href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">pn_transport_bind</a></div><div class="ttdeci">int pn_transport_bind(pn_transport_t *transport, pn_connection_t *connection)</div><div class="ttdoc">Binds the transport to an AMQP connection. </div></div>
 <div class="ttc" id="group__transport_html_ga55c589d9b3e69057b130036c3c2173df"><div class="ttname"><a href="group__transport.html#ga55c589d9b3e69057b130036c3c2173df">pn_transport_closed</a></div><div class="ttdeci">bool pn_transport_closed(pn_transport_t *transport)</div><div class="ttdoc">Equivalent to pn_transport_head_closed(transport) &amp;&amp; pn_transport_tail_closed(transport) ...</div></div>
-<div class="ttc" id="group__transport_html_ga93f5efd9d63ebd1b1498fdace388ec3d"><div class="ttname"><a href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a></div><div class="ttdeci">ssize_t pn_transport_input(pn_transport_t *transport, const char *bytes, size_t available)</div></div>
+<div class="ttc" id="group__transport_html_ga93f5efd9d63ebd1b1498fdace388ec3d"><div class="ttname"><a href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a></div><div class="ttdeci">ssize_t pn_transport_input(pn_transport_t *transport, const char *bytes, size_t available)</div><div class="ttdoc">Deprecated </div></div>
 <div class="ttc" id="group__transport_html_ga31470f0b0dbfd2c8c2929cc170858dc9"><div class="ttname"><a href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9">pn_transport_pop</a></div><div class="ttdeci">void pn_transport_pop(pn_transport_t *transport, size_t size)</div><div class="ttdoc">Removes size bytes of output from the pending output queue following the transport&amp;#39;s head pointer...</div></div>
 <div class="ttc" id="group__transport_html_ga6b2750a2d313c65aabe5dc8a99f1de58"><div class="ttname"><a href="group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58">pn_transport_get_user</a></div><div class="ttdeci">const char * pn_transport_get_user(pn_transport_t *transport)</div><div class="ttdoc">Retrieve the authenticated user. </div></div>
 <div class="ttc" id="group__transport_html_gaa079bb5f5b9ea10734c9d8af26fba333"><div class="ttname"><a href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">pn_transport_capacity</a></div><div class="ttdeci">ssize_t pn_transport_capacity(pn_transport_t *transport)</div><div class="ttdoc">Get the amount of free space for input following the transport&amp;#39;s tail pointer. </div></div>
-<div class="ttc" id="group__transport_html_ga000b2b9ab82139defb1a103f220ec58e"><div class="ttname"><a href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a></div><div class="ttdeci">void * pn_transport_get_context(pn_transport_t *transport)</div></div>
+<div class="ttc" id="group__transport_html_ga000b2b9ab82139defb1a103f220ec58e"><div class="ttname"><a href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a></div><div class="ttdeci">void * pn_transport_get_context(pn_transport_t *transport)</div><div class="ttdoc">Deprecated - Use pn_transport_attachments(). </div></div>
 <div class="ttc" id="group__transport_html_ga0f2abc6827e9370c0aebb2e5dd7535a9"><div class="ttname"><a href="group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9">pn_transport_tick</a></div><div class="ttdeci">pn_timestamp_t pn_transport_tick(pn_transport_t *transport, pn_timestamp_t now)</div><div class="ttdoc">Process any pending transport timer events. </div></div>
 <div class="ttc" id="group__transport_html_gaeb7e30ead4a6ab080d0005379be20e34"><div class="ttname"><a href="group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34">pn_transport_require_encryption</a></div><div class="ttdeci">void pn_transport_require_encryption(pn_transport_t *transport, bool required)</div><div class="ttdoc">Set whether a non encrypted transport connection is allowed. </div></div>
 <div class="ttc" id="condition_8h_html"><div class="ttname"><a href="condition_8h.html">condition.h</a></div><div class="ttdoc">An endpoint error state. </div></div>
@@ -124,10 +124,10 @@ $(document).ready(function(){initNavTree('transport_8h_source.html','');});
 <div class="ttc" id="group__transport_html_ga8f080d7fb1e7fea2c93391d0b8f59773"><div class="ttname"><a href="group__transport.html#ga8f080d7fb1e7fea2c93391d0b8f59773">pn_transport_set_channel_max</a></div><div class="ttdeci">int pn_transport_set_channel_max(pn_transport_t *transport, uint16_t channel_max)</div><div class="ttdoc">Set the maximum allowed channel number for a transport. </div></div>
 <div class="ttc" id="group__transport_html_gab8d0c7878d3d8ecda627678a6ec55072"><div class="ttname"><a href="group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072">pn_transport_close_head</a></div><div class="ttdeci">int pn_transport_close_head(pn_transport_t *transport)</div><div class="ttdoc">Indicate that the output has closed. </div></div>
 <div class="ttc" id="group__transport_html_gaff7c08aeb92596ad9d269468d1557647"><div class="ttname"><a href="group__transport.html#gaff7c08aeb92596ad9d269468d1557647">pn_transport_remote_channel_max</a></div><div class="ttdeci">uint16_t pn_transport_remote_channel_max(pn_transport_t *transport)</div><div class="ttdoc">Get the maximum allowed channel of a transport&amp;#39;s remote peer. </div></div>
-<div class="ttc" id="group__transport_html_gac22041ff85d1a1f5287ac2ba826edb74"><div class="ttname"><a href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a></div><div class="ttdeci">void pn_transport_set_context(pn_transport_t *transport, void *context)</div></div>
+<div class="ttc" id="group__transport_html_gac22041ff85d1a1f5287ac2ba826edb74"><div class="ttname"><a href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a></div><div class="ttdeci">void pn_transport_set_context(pn_transport_t *transport, void *context)</div><div class="ttdoc">Deprecated - Use pn_transport_attachments(). </div></div>
 <div class="ttc" id="group__transport_html_ga7eb7915459eb433e68ff5ce80c5020a7"><div class="ttname"><a href="group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7">pn_transport_set_tracer</a></div><div class="ttdeci">void pn_transport_set_tracer(pn_transport_t *transport, pn_tracer_t tracer)</div><div class="ttdoc">Set the tracing function used by a transport. </div></div>
 <div class="ttc" id="group__transport_html_ga30d129d04a387ea34515c1641b83521b"><div class="ttname"><a href="group__transport.html#ga30d129d04a387ea34515c1641b83521b">pn_transport_get_tracer</a></div><div class="ttdeci">pn_tracer_t pn_transport_get_tracer(pn_transport_t *transport)</div><div class="ttdoc">Get the tracing function used by a transport. </div></div>
-<div class="ttc" id="group__transport_html_gaede0bc2a0038ccdc7e1b193e322147fa"><div class="ttname"><a href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a></div><div class="ttdeci">pn_error_t * pn_transport_error(pn_transport_t *transport)</div></div>
+<div class="ttc" id="group__transport_html_gaede0bc2a0038ccdc7e1b193e322147fa"><div class="ttname"><a href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a></div><div class="ttdeci">pn_error_t * pn_transport_error(pn_transport_t *transport)</div><div class="ttdoc">Deprecated </div></div>
 <div class="ttc" id="group__transport_html_gad603e8d72578bcedd2d9235f74f28f37"><div class="ttname"><a href="group__transport.html#gad603e8d72578bcedd2d9235f74f28f37">pn_transport_log</a></div><div class="ttdeci">void pn_transport_log(pn_transport_t *transport, const char *message)</div><div class="ttdoc">Log a message using a transport&amp;#39;s logging mechanism. </div></div>
 <div class="ttc" id="group__transport_html_ga4695788da8491f0c7104bfe36634ff94"><div class="ttname"><a href="group__transport.html#ga4695788da8491f0c7104bfe36634ff94">pn_trace_t</a></div><div class="ttdeci">int pn_trace_t</div><div class="ttdoc">Holds the trace flags for an AMQP transport. </div><div class="ttdef"><b>Definition:</b> transport.h:57</div></div>
 <div class="ttc" id="group__transport_html_ga1f52a6f11322873e74b9daf004269a91"><div class="ttname"><a href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91">pn_transport_process</a></div><div class="ttdeci">int pn_transport_process(pn_transport_t *transport, size_t size)</div><div class="ttdoc">Process input data following the tail pointer. </div></div>
@@ -137,8 +137,8 @@ $(document).ready(function(){initNavTree('transport_8h_source.html','');});
 <div class="ttc" id="group__transport_html_ga3ef8b0032b2a012c697e853e363338ea"><div class="ttname"><a href="group__transport.html#ga3ef8b0032b2a012c697e853e363338ea">pn_transport_head</a></div><div class="ttdeci">const char * pn_transport_head(pn_transport_t *transport)</div><div class="ttdoc">Get the transport&amp;#39;s head pointer. </div></div>
 <div class="ttc" id="group__transport_html_gae9b49fcbf6397e6916eb4e1357c90ff3"><div class="ttname"><a href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a></div><div class="ttdeci">void(* pn_tracer_t)(pn_transport_t *transport, const char *message)</div><div class="ttdoc">Callback for customizing logging behaviour. </div><div class="ttdef"><b>Definition:</b> transport.h:62</div></div>
 <div class="ttc" id="group__transport_html_ga81adf1fd6fa28054f2f80c424aa98122"><div class="ttname"><a href="group__transport.html#ga81adf1fd6fa28054f2f80c424aa98122">pn_transport_pending</a></div><div class="ttdeci">ssize_t pn_transport_pending(pn_transport_t *transport)</div><div class="ttdoc">Get the number of pending output bytes following the transport&amp;#39;s head pointer. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
-<div class="ttc" id="group__transport_html_gae72fdee3b8aae3cb484b0ed98c2b802e"><div class="ttname"><a href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a></div><div class="ttdeci">ssize_t pn_transport_output(pn_transport_t *transport, char *bytes, size_t size)</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
+<div class="ttc" id="group__transport_html_gae72fdee3b8aae3cb484b0ed98c2b802e"><div class="ttname"><a href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a></div><div class="ttdeci">ssize_t pn_transport_output(pn_transport_t *transport, char *bytes, size_t size)</div><div class="ttdoc">Deprecated </div></div>
 <div class="ttc" id="group__transport_html_gac458d9fdb684f9501e89b96fc51f5c34"><div class="ttname"><a href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a></div><div class="ttdeci">pn_condition_t * pn_transport_condition(pn_transport_t *transport)</div><div class="ttdoc">Get additional information about the condition of the transport. </div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
 <div class="ttc" id="group__transport_html_ga6ab28051242631d9bea4814e8670ab90"><div class="ttname"><a href="group__transport.html#ga6ab28051242631d9bea4814e8670ab90">pn_transport_free</a></div><div class="ttdeci">void pn_transport_free(pn_transport_t *transport)</div><div class="ttdoc">Free a transport object. </div></div>
@@ -148,7 +148,7 @@ $(document).ready(function(){initNavTree('transport_8h_source.html','');});
 <div class="ttc" id="group__transport_html_ga3eb018b426d168de8c8d9b3441be036c"><div class="ttname"><a href="group__transport.html#ga3eb018b426d168de8c8d9b3441be036c">pn_transport_head_closed</a></div><div class="ttdeci">bool pn_transport_head_closed(pn_transport_t *transport)</div><div class="ttdoc">True if pn_transport_close_head() has been called. </div></div>
 <div class="ttc" id="group__transport_html_gaf9833d93faf6a6ed68039e4a909cdd77"><div class="ttname"><a href="group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77">pn_transport</a></div><div class="ttdeci">pn_transport_t * pn_transport(void)</div><div class="ttdoc">Factory for creating a transport. </div></div>
 <div class="ttc" id="group__transport_html_gac5bebd26c0942bc17d7fad36577110f8"><div class="ttname"><a href="group__transport.html#gac5bebd26c0942bc17d7fad36577110f8">pn_transport_set_server</a></div><div class="ttdeci">void pn_transport_set_server(pn_transport_t *transport)</div><div class="ttdoc">Configure a transport as a server. </div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:168</div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 <div class="ttc" id="group__transport_html_ga2a66ff267333651eb166f3f6fa4ede50"><div class="ttname"><a href="group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50">pn_transport_unbind</a></div><div class="ttdeci">int pn_transport_unbind(pn_transport_t *transport)</div><div class="ttdoc">Unbinds a transport from its AMQP connection. </div></div>
 <div class="ttc" id="group__transport_html_ga2b98f594e012c24e7b17dcc91e3d4caf"><div class="ttname"><a href="group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf">pn_transport_connection</a></div><div class="ttdeci">pn_connection_t * pn_transport_connection(pn_transport_t *transport)</div><div class="ttdoc">Access the AMQP Connection associated with the transport. </div></div>
 <div class="ttc" id="group__transport_html_ga46552ed46e59de6530d2eee03707a51b"><div class="ttname"><a href="group__transport.html#ga46552ed46e59de6530d2eee03707a51b">pn_transport_get_max_frame</a></div><div class="ttdeci">uint32_t pn_transport_get_max_frame(pn_transport_t *transport)</div><div class="ttdoc">Get the maximum frame size of a transport. </div></div>


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


[45/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/direct_8c-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/direct_8c-example.html b/content/releases/qpid-proton-master/proton/c/api/direct_8c-example.html
index d520f51..36a0010 100755
--- a/content/releases/qpid-proton-master/proton/c/api/direct_8c-example.html
+++ b/content/releases/qpid-proton-master/proton/c/api/direct_8c-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('direct_8c-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>A server that can be used to demonstrate direct (no broker) peer-to-peer communication It can accept an incoming connection from either the <a class="el" href="send_8c-example.html">send.c</a> or <a class="el" href="receive_8c-example.html">receive.c</a> examples and will act as the directly-connected counterpart (receive or send)</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8h.html">proton/connection.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8h.html">proton/delivery.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8h.html">proton/listener.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8h.html">proton/message.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="proactor_8h.html">proton/proactor.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sasl_8h.html">proton/sasl.h</a>&gt;</span><
 /div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="session_8h.html">proton/session.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;stdio.h&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;stdlib.h&gt;</span></div><div class="line"></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>app_data_t {</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *host, *port;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *amqp_address;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *container_id;</div><div class="line">  <span class="keywordtype">int</span> mes
 sage_count;</div><div class="line"></div><div class="line">  <a class="code" href="types_8h.html#abba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor;</div><div class="line">  <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener;</div><div class="line">  <a name="_a0"></a><a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> message_buffer;</div><div class="line"></div><div class="line">  <span class="comment">/* Sender values */</span></div><div class="line">  <span class="keywordtype">int</span> sent;</div><div class="line">  <span class="keywordtype">int</span> acknowledged;</div><div class="line">  <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender;</div><div class="line"></div><div class="line">  <span class="comment">/* Receiver values */</span></div><div class="line">  <span class="keywordtype">int</span> received;</div><div class="line">
 } app_data_t;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">int</span> BATCH = 1000; <span class="comment">/* Batch size for unlimited receive */</span></div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">int</span> exit_code = 0;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> check_condition(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *cond) {</div><div class="line">  <span class="keywordflow">if</span> (<a name="a1"></a><a class="code" href="group__condition.html#ga112611a7a4087e050c476a430db2cfb9">pn_condition_is_set</a>(cond)) {</div><div class="line">    fprintf(stderr, <span class="stringliteral">&quot;%s
 : %s: %s\n&quot;</span>, <a name="a2"></a><a class="code" href="group__event.html#ga3a85c046c11ce692c23b9566b022d54b">pn_event_type_name</a>(<a name="a3"></a><a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(e)),</div><div class="line">            <a name="a4"></a><a class="code" href="group__condition.html#ga05b0d374d90f11d9ebbf818662569689">pn_condition_get_name</a>(cond), <a name="a5"></a><a class="code" href="group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8">pn_condition_get_description</a>(cond));</div><div class="line">    <a name="a6"></a><a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a name="a7"></a><a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e));</div><div class="line">    exit_code = 1;</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* 
 Create a message with a map { &quot;sequence&quot; : number } encode it and return the encoded buffer. */</span></div><div class="line"><span class="keyword">static</span> <a name="_a8"></a><a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> encode_message(app_data_t* app) {</div><div class="line">  <span class="comment">/* Construct a message with the map { &quot;sequence&quot;: app.sent } */</span></div><div class="line">  <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a>* message = <a name="a9"></a><a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>();</div><div class="line">  <a name="a10"></a><a class="code" href="group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016">pn_data_put_int</a>(<a name="a11"></a><a class="code" href="group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de">pn_message_id</a>(message), app-&gt;sent); <span class="comment">/* Set the message_id 
 also */</span></div><div class="line">  <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a>* body = <a name="a12"></a><a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(message);</div><div class="line">  <a name="a13"></a><a class="code" href="group__data.html#ga4c77c7a884bbd9a757b31060962d8543">pn_data_put_map</a>(body);</div><div class="line">  <a name="a14"></a><a class="code" href="group__data.html#ga1093449b80357dabf3f70a4bf804f4f7">pn_data_enter</a>(body);</div><div class="line">  <a name="a15"></a><a class="code" href="group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee">pn_data_put_string</a>(body, <a name="a16"></a><a class="code" href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(<span class="keyword">sizeof</span>(<span class="stringliteral">&quot;sequence&quot;</span>)-1, <span class="stringliteral">&quot;sequence&quot;</span>));</div><div class="line">  <a clas
 s="code" href="group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016">pn_data_put_int</a>(body, app-&gt;sent); <span class="comment">/* The sequence number */</span></div><div class="line">  <a name="a17"></a><a class="code" href="group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48">pn_data_exit</a>(body);</div><div class="line"></div><div class="line">  <span class="comment">/* encode the message, expanding the encode buffer as needed */</span></div><div class="line">  <span class="keywordflow">if</span> (app-&gt;message_buffer.start == NULL) {</div><div class="line">    <span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">size_t</span> initial_size = 128;</div><div class="line">    app-&gt;message_buffer = <a name="a18"></a><a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(initial_size, (<span class="keywordtype">char</span>*)malloc(initial_size));</div><div class="line">  }</div><div class="li
 ne">  <span class="comment">/* app-&gt;message_buffer is the total buffer space available. */</span></div><div class="line">  <span class="comment">/* mbuf wil point at just the portion used by the encoded message */</span></div><div class="line">  <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> mbuf = <a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(app-&gt;message_buffer.size, app-&gt;message_buffer.start);</div><div class="line">  <span class="keywordtype">int</span> status = 0;</div><div class="line">  <span class="keywordflow">while</span> ((status = <a name="a19"></a><a class="code" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a>(message, mbuf.<a name="a20"></a>start, &amp;mbuf.<a name="a21"></a>size)) == <a name="a22"></a><a class="code" href="group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7">PN_OVERFLOW</a>) {</div><div class="line">    app-&gt;message_b
 uffer.size *= 2;</div><div class="line">    app-&gt;message_buffer.start = (<span class="keywordtype">char</span>*)realloc(app-&gt;message_buffer.start, app-&gt;message_buffer.size);</div><div class="line">    mbuf.size = app-&gt;message_buffer.size;</div><div class="line">  }</div><div class="line">  <span class="keywordflow">if</span> (status != 0) {</div><div class="line">    fprintf(stderr, <span class="stringliteral">&quot;error encoding message: %s\n&quot;</span>, <a name="a23"></a><a class="code" href="group__error.html#ga67cbe6ebb143370e0604f5b84d716c56">pn_error_text</a>(<a name="a24"></a><a class="code" href="group__message.html#ga9ad09178e7682efde76e2d39f352dfe8">pn_message_error</a>(message)));</div><div class="line">    exit(1);</div><div class="line">  }</div><div class="line">  <a name="a25"></a><a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(message);</div><div class="line">  <span class="keywordflow">return</span> <a
  class="code" href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(mbuf.size, mbuf.start);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="preprocessor">#define MAX_SIZE 1024</span></div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> decode_message(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *dlv) {</div><div class="line">  <span class="keyword">static</span> <span class="keywordtype">char</span> buffer[MAX_SIZE];</div><div class="line">  ssize_t len;</div><div class="line">  <span class="comment">// try to decode the message body</span></div><div class="line">  <span class="keywordflow">if</span> (<a name="a26"></a><a class="code" href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a>(dlv) &lt; MAX_SIZE) {</div><div class="line">    <span class="comment">// read in the 
 raw data</span></div><div class="line">    len = <a name="a27"></a><a class="code" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_recv</a>(<a name="a28"></a><a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(dlv), buffer, MAX_SIZE);</div><div class="line">    <span class="keywordflow">if</span> (len &gt; 0) {</div><div class="line">      <span class="comment">// decode it into a proton message</span></div><div class="line">      <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *m = <a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>();</div><div class="line">      <span class="keywordflow">if</span> (<a name="a29"></a><a class="code" href="group__error.html#gac73fbd2363c5f562f85dde459e631394">PN_OK</a> == <a name="a30"></a><a class="code" href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">pn_message_decode</a>(m, buffe
 r, len)) {</div><div class="line">        pn_string_t *s = pn_string(NULL);</div><div class="line">        pn_inspect(<a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(m), s);</div><div class="line">        printf(<span class="stringliteral">&quot;%s\n&quot;</span>, pn_string_get(s));</div><div class="line">        pn_free(s);</div><div class="line">      }</div><div class="line">      <a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(m);</div><div class="line">    }</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* This function handles events when we are acting as the receiver */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> handle_receive(app_data_t* app, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* event) {</
 div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(event)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a31"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307">PN_LINK_REMOTE_OPEN</a>: {</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a name="a32"></a><a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event);</div><div class="line">     <a name="a33"></a><a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(l);</div><div class="line">     <a name="a34"></a><a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(l, app-&gt;message_count ? app-&gt;message_count : BATCH);</div
 ><div class="line">   } <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a35"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a>: {</div><div class="line">     <span class="comment">/* A message has been received */</span></div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link = NULL;</div><div class="line">     <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *dlv = <a name="a36"></a><a class="code" href="group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a>(event);</div><div class="line">     <span class="keywordflow">if</span> (<a name="a37"></a><a class="code" href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a>(dlv) &amp;&amp; !<a name="a38"></
 a><a class="code" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a>(dlv)) {</div><div class="line">       link = <a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(dlv);</div><div class="line">       decode_message(dlv);</div><div class="line">       <span class="comment">/* Accept the delivery */</span></div><div class="line">       <a name="a39"></a><a class="code" href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a>(dlv, <a name="a40"></a><a class="code" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">PN_ACCEPTED</a>);</div><div class="line">       <span class="comment">/* done with the delivery, move to the next and free it */</span></div><div class="line">       <a name="a41"></a><a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(link);</div><div class="line">       <a name="a42"></a><a class="code" hre
 f="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(dlv);  <span class="comment">/* dlv is now freed */</span></div><div class="line"></div><div class="line">       <span class="keywordflow">if</span> (app-&gt;message_count == 0) {</div><div class="line">         <span class="comment">/* receive forever - see if more credit is needed */</span></div><div class="line">         <span class="keywordflow">if</span> (<a name="a43"></a><a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(link) &lt; BATCH/2) {</div><div class="line">           <span class="comment">/* Grant enough credit to bring it up to BATCH: */</span></div><div class="line">           <a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(link, BATCH - <a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(link));</div><div class="line">         }</div><div class="line">    
    } <span class="keywordflow">else</span> <span class="keywordflow">if</span> (++app-&gt;received &gt;= app-&gt;message_count) {</div><div class="line">         <span class="comment">/* done receiving, close the endpoints */</span></div><div class="line">         printf(<span class="stringliteral">&quot;%d messages received\n&quot;</span>, app-&gt;received);</div><div class="line">         <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *ssn = <a name="a44"></a><a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(link);</div><div class="line">         <a name="a45"></a><a class="code" href="group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d">pn_link_close</a>(link);</div><div class="line">         <a name="a46"></a><a class="code" href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a>(ssn);</div><div class="line">         <a class="code" href="group__connection.html
 #gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a name="a47"></a><a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(ssn));</div><div class="line">       }</div><div class="line">     }</div><div class="line">   } <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</span>:</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* This function handles events when we are acting as the sender */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> handle_send(app_data_t* app, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* event) {</div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__
 event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(event)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307">PN_LINK_REMOTE_OPEN</a>: {</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>* l = <a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event);</div><div class="line">     <a name="a48"></a><a class="code" href="group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1">pn_terminus_set_address</a>(<a name="a49"></a><a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a>(l), app-&gt;amqp_address);</div><div class="line">     <a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(l);</div><div class="line">   } <span class="keywordflow">bre
 ak</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a50"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f">PN_LINK_FLOW</a>: {</div><div class="line">     <span class="comment">/* The peer has given us some credit, now we can send messages */</span></div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender = <a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event);</div><div class="line">     <span class="keywordflow">while</span> (<a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(sender) &gt; 0 &amp;&amp; app-&gt;sent &lt; app-&gt;message_count) {</div><div class="line">       ++app-&gt;sent;</div><div class="line">       <span class="comment">// Use sent counter as unique delivery tag.</span></div><div class="l
 ine">       <a name="a51"></a><a class="code" href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a>(sender, <a name="a52"></a><a class="code" href="group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a>((<span class="keyword">const</span> <span class="keywordtype">char</span> *)&amp;app-&gt;sent, <span class="keyword">sizeof</span>(app-&gt;sent)));</div><div class="line">       <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> msgbuf = encode_message(app);</div><div class="line">       <a name="a53"></a><a class="code" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9">pn_link_send</a>(sender, msgbuf.<a name="a54"></a>start, msgbuf.<a name="a55"></a>size);</div><div class="line">       <a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(sender);</div><div class="line">     }</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">
    }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a>: {</div><div class="line">     <span class="comment">/* We received acknowledgedment from the peer that a message was delivered. */</span></div><div class="line">     <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a>* d = <a class="code" href="group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a>(event);</div><div class="line">     <span class="keywordflow">if</span> (<a name="a56"></a><a class="code" href="group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a>(d) == <a class="code" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">PN_ACCEPTED</a>) {</div><div class="line">       <span class="keywordflow">if</span> (++app-&gt;acknowledged == app-&gt;message
 _count) {</div><div class="line">         printf(<span class="stringliteral">&quot;%d messages sent and acknowledged\n&quot;</span>, app-&gt;acknowledged);</div><div class="line">         <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">         <span class="comment">/* Continue handling events till we receive TRANSPORT_CLOSED */</span></div><div class="line">       }</div><div class="line">     }</div><div class="line">   } <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</span>:</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Handle all events, delegate to handle_send or handle_rece
 ive depending on link mode.</span></div><div class="line"><span class="comment">   Return true to continue, false to exit</span></div><div class="line"><span class="comment">*/</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">bool</span> handle(app_data_t* app, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* event) {</div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(event)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a57"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a>:</div><div class="line">    printf(<span class="stringliteral">&quot;listening\n&quot;</span>);</div><div class="line">    fflush(stdout);</div><div class="line">    <span class="keywo
 rdflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a58"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a>:</div><div class="line">    <a name="a59"></a><a class="code" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a>(<a name="a60"></a><a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(event), <a name="a61"></a><a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>());</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a62"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e">PN_CONNECTION_INIT</a>:</div><div class="line">    <a nam
 e="a63"></a><a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event), app-&gt;container_id);</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a64"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5">PN_CONNECTION_BOUND</a>: {</div><div class="line">     <span class="comment">/* Turn off security */</span></div><div class="line">     <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t = <a name="a65"></a><a class="code" href="group__event.html#ga14525ae84870388141898bbf57f2b151">pn_event_transport</a>(event);</div><div class="line">     <a name="a66"></a><a class="code" href="group__transport.html#ga2
 85b4cced59c665ae178adf26128d3fc">pn_transport_require_auth</a>(t, <span class="keyword">false</span>);</div><div class="line">     <a name="a67"></a><a class="code" href="group__sasl.html#ga73299a6a22e141e7911a739590032625">pn_sasl_allowed_mechs</a>(<a name="a68"></a><a class="code" href="group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c">pn_sasl</a>(t), <span class="stringliteral">&quot;ANONYMOUS&quot;</span>);</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a69"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc">PN_CONNECTION_REMOTE_OPEN</a>: {</div><div class="line">     <a name="a70"></a><a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event)); <span class="comment">/* Complete the open */</span></div><div clas
 s="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a71"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806">PN_SESSION_REMOTE_OPEN</a>: {</div><div class="line">     <a name="a72"></a><a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(<a name="a73"></a><a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(event));</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a74"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a>:</div><div class="line">    check_condition(event, <a name="a75">
 </a><a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a>(<a class="code" href="group__event.html#ga14525ae84870388141898bbf57f2b151">pn_event_transport</a>(event)));</div><div class="line">    <a name="a76"></a><a class="code" href="group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104">pn_listener_close</a>(app-&gt;listener); <span class="comment">/* Finished */</span></div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a77"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f">PN_CONNECTION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a78"></a><a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2c
 caf52">pn_event_connection</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a79"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135">PN_SESSION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a80"></a><a class="code" href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a>(<a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connect
 ion_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a81"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f">PN_LINK_REMOTE_CLOSE</a>:</div><div class="line">   <span class="keywordflow">case</span> <a name="a82"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2">PN_LINK_REMOTE_DETACH</a>:</div><div class="line">    check_condition(event, <a name="a83"></a><a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event)));</div><div class="line">    <a class="code" href="group__connection.htm
 l#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a84"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe">PN_PROACTOR_TIMEOUT</a>:</div><div class="line">    <span class="comment">/* Wake the sender&#39;s connection */</span></div><div class="line">    <a name="a85"></a><a class="code" href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560">pn_connection_wake</a>(<a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(<a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(app-&gt;sender)));</div><div class="line">    <span class="keywordflow">break
 </span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a86"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca">PN_LISTENER_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a87"></a><a class="code" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a>(<a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(event)));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a88"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a>:</div><div class="line">    <span class="keywordflow">return</span> <span class="keyword">false</span>;</div><div class="line">    <span class="keywordflow">
 break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</span>: {</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event);</div><div class="line">     <span class="keywordflow">if</span> (l) {                      <span class="comment">/* Only delegate link-related events */</span></div><div class="line">       <span class="keywordflow">if</span> (<a name="a89"></a><a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(l)) {</div><div class="line">         handle_send(app, event);</div><div class="line">       } <span class="keywordflow">else</span> {</div><div class="line">         handle_receive(app, event);</div><div class="line">       }</div><div class="line">     }</div><div class="line">   }</div><div class="line">  }</div><div c
 lass="line">  <span class="keywordflow">return</span> <span class="keyword">true</span>;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> run(app_data_t *app) {</div><div class="line">  <span class="comment">/* Loop and handle events */</span></div><div class="line">  <span class="keywordflow">do</span> {</div><div class="line">    <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events = <a name="a90"></a><a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(app-&gt;proactor);</div><div class="line">    <span class="keywordflow">for</span> (<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e = <a name="a91"></a><a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a>(events); e; e = <a class="code" href="group__event.html#gac3fbf151357d3101ac294
 cb675348c76">pn_event_batch_next</a>(events)) {</div><div class="line">      <span class="keywordflow">if</span> (!handle(app, e)) {</div><div class="line">        <span class="keywordflow">return</span>;</div><div class="line">      }</div><div class="line">    }</div><div class="line">    <a name="a92"></a><a class="code" href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a>(app-&gt;proactor, events);</div><div class="line">  } <span class="keywordflow">while</span>(<span class="keyword">true</span>);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">  <span class="keyword">struct </span>app_data_t app = {0};</div><div class="line">  <span class="keywordtype">int</span> i = 0;</div><div class="line">  app.container_id = argv[i++];   <span class="comment">/* Should be unique */
 </span></div><div class="line">  app.host = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;&quot;</span>;</div><div class="line">  app.port = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;amqp&quot;</span>;</div><div class="line">  app.amqp_address = (argc &gt; i) ? argv[i++] : <span class="stringliteral">&quot;examples&quot;</span>;</div><div class="line">  app.message_count = (argc &gt; i) ? atoi(argv[i++]) : 10;</div><div class="line"></div><div class="line">  <span class="comment">/* Create the proactor and connect */</span></div><div class="line">  app.proactor = <a name="a93"></a><a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>();</div><div class="line">  app.listener = <a name="a94"></a><a class="code" href="group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5">pn_listener</a>();</div><div class="line">  <span class="keywordtype">char</span> addr[<a name="a95"></a><a class="code" href="group__proa
 ctor.html#ga29ae114b42fb797c103dc9883ebcb256">PN_MAX_ADDR</a>];</div><div class="line">  <a name="a96"></a><a class="code" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a>(addr, <span class="keyword">sizeof</span>(addr), app.host, app.port);</div><div class="line">  <a name="a97"></a><a class="code" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a>(app.proactor, app.listener, addr, 16);</div><div class="line">  run(&amp;app);</div><div class="line">  <a name="a98"></a><a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(app.proactor);</div><div class="line">  free(app.message_buffer.start);</div><div class="line">  <span class="keywordflow">return</span> exit_code;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/engine_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/engine_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/engine_8h_source.html
index 1c9dc70..b888568 100755
--- a/content/releases/qpid-proton-master/proton/c/api/engine_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/engine_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/engine.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('engine_8h_source.html','');});
 </div><!--header-->
 <div class="contents">
 <div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ENGINE_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ENGINE_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="
 l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><spa
 n class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   
 20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="connection_8h.html">proton/connection.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><sp
 an class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="session_8h.html">proton/session.h</a>&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="terminus_8h.html">proton/terminus.h</a>&gt;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="delivery_8h.html">proton/delivery.h</a>&gt;</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#1
 60;<span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* engine.h */</span><span class="preprocessor"></span></div><div class="ttc" id="transport_8h_html"><div class="ttname"><a href="transport_8h.html">transport.h</a></div><div class="ttdoc">A network channel supporting an AMQP connection. </div></div>
-<div class="ttc" id="connection_8h_html"><div class="ttname"><a href="connection_8h.html">connection.h</a></div><div class="ttdoc">A channel for communication between two peers on a network. </div></div>
+<div class="ttc" id="connection_8h_html"><div class="ttname"><a href="connection_8h.html">connection.h</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div></div>
 <div class="ttc" id="session_8h_html"><div class="ttname"><a href="session_8h.html">session.h</a></div><div class="ttdoc">A container of links. </div></div>
 <div class="ttc" id="terminus_8h_html"><div class="ttname"><a href="terminus_8h.html">terminus.h</a></div><div class="ttdoc">A source or target for messages. </div></div>
 <div class="ttc" id="condition_8h_html"><div class="ttname"><a href="condition_8h.html">condition.h</a></div><div class="ttdoc">An endpoint error state. </div></div>
@@ -109,7 +109,7 @@ $(document).ready(function(){initNavTree('engine_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>engine.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/error_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/error_8h.html b/content/releases/qpid-proton-master/proton/c/api/error_8h.html
index cb9144a..5f8fe34 100755
--- a/content/releases/qpid-proton-master/proton/c/api/error_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/error_8h.html
@@ -149,8 +149,12 @@ Macros</h2></td></tr>
 <tr class="separator:gafbb090366e9dbf9a5bb0735df1e23d33"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="memItemLeft" align="right" valign="top">
 #define&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d">PN_OUT_OF_MEMORY</a></td></tr>
-<tr class="memdesc:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Out-of-momory error. <br /></td></tr>
+<tr class="memdesc:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Out-of-memory error. <br /></td></tr>
 <tr class="separator:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga82db456291c2627e31becc44b733a7f0"><td class="memItemLeft" align="right" valign="top">
+#define&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0">PN_ABORTED</a></td></tr>
+<tr class="memdesc:ga82db456291c2627e31becc44b733a7f0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Delivery aborted error. <br /></td></tr>
+<tr class="separator:ga82db456291c2627e31becc44b733a7f0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="typedef-members"></a>
 Typedefs</h2></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/error_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/error_8h.js b/content/releases/qpid-proton-master/proton/c/api/error_8h.js
index cbf52e1..047c165 100755
--- a/content/releases/qpid-proton-master/proton/c/api/error_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/error_8h.js
@@ -11,6 +11,7 @@ var error_8h =
     [ "PN_INTR", "group__error.html#ga53284958be0c328f90ca3a4a0793d965", null ],
     [ "PN_INPROGRESS", "group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33", null ],
     [ "PN_OUT_OF_MEMORY", "group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d", null ],
+    [ "PN_ABORTED", "group__error.html#ga82db456291c2627e31becc44b733a7f0", null ],
     [ "pn_error_t", "group__error.html#ga24a289d5b32c9bd8a775600a5af83d52", null ],
     [ "pn_code", "group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64", null ],
     [ "pn_error", "group__error.html#ga0992aa0df5290a2ae639246b0c2f5481", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/error_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/error_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/error_8h_source.html
index 52c1af1..b072e6a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/error_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/error_8h_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('error_8h_source.html','');});
 <div class="title">error.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="error_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ERROR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ERROR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreement
 s.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comm
 ent"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div>
 <div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160
 ;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno"><a class="line" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">   44</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a>;</div><div class="line"><a name="l00045"></a><span class="linen
 o">   45</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno"><a class="line" href="group__error.html#gac73fbd2363c5f562f85dde459e631394">   46</a></span>&#160;<span class="preprocessor">#define PN_OK (0)              </span></div><div class="line"><a name="l00047"></a><span class="lineno"><a class="line" href="group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3">   47</a></span>&#160;<span class="preprocessor">#define PN_EOS (-1)            </span></div><div class="line"><a name="l00048"></a><span class="lineno"><a class="line" href="group__error.html#ga664f7bdd616c30b72bd50bcc17839c81">   48</a></span>&#160;<span class="preprocessor">#define PN_ERR (-2)            </span></div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7">   49</a></span>&#160;<span class="preprocessor">#define PN_OVERFLOW (-3)       </span></div><div class="line"><a name="l00050"></a><span class="li
 neno"><a class="line" href="group__error.html#ga3317339fb405435df42fa93d62f0e14c">   50</a></span>&#160;<span class="preprocessor">#define PN_UNDERFLOW (-4)      </span></div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="group__error.html#ga5efbe6093556326613d2ccd3864a00aa">   51</a></span>&#160;<span class="preprocessor">#define PN_STATE_ERR (-5)      </span></div><div class="line"><a name="l00052"></a><span class="lineno"><a class="line" href="group__error.html#ga5551b7172de89dc540bd7c2beedd325a">   52</a></span>&#160;<span class="preprocessor">#define PN_ARG_ERR (-6)        </span></div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2">   53</a></span>&#160;<span class="preprocessor">#define PN_TIMEOUT (-7)        </span></div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="group__error.html#ga53284958be0c328f90ca3a4a0793d965"
 >   54</a></span>&#160;<span class="preprocessor">#define PN_INTR (-8)           </span></div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33">   55</a></span>&#160;<span class="preprocessor">#define PN_INPROGRESS (-9)     </span></div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d">   56</a></span>&#160;<span class="preprocessor">#define PN_OUT_OF_MEMORY (-10) </span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">PN_EXTERN const char *pn_code(int code);</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="g
 roup__error.html#ga0992aa0df5290a2ae639246b0c2f5481">pn_error</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    </div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__error.html#ga5e57528759aedb00e68aafd0d025d06c">pn_error_free</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__error.html#ga15440ed9515967950fa4504a53fc0b64">pn_error_clear</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00078"></a><span class="lineno">   
 78</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d">pn_error_set</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *text);</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga59db2b3acdca714819c6450d2d5440a1">pn_error_vformat</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_
 list ap);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2">pn_error_format</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c">pn_error_code</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00100"></
 a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__error.html#ga67cbe6ebb143370e0604f5b84d716c56">pn_error_text</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3">pn_error_copy</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *src);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div>
 <div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">#define PN_RETURN_IF_ERROR(x) \</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">do {\</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">int r = (x);\</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;<span class="preprocessor">if (r &lt; 0) return r; \</span></div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">} while (0)</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;}</div><div class="line"
 ><a name="l00130"></a><span class="lineno">  130</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* error.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__error_html_ga96ccb65768c64ee0a1b71b83e08489d3"><div class="ttname"><a href="group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3">pn_error_copy</a></div><div class="ttdeci">int pn_error_copy(pn_error_t *error, pn_error_t *src)</div><div class="ttdoc">Copy the src error. </div></div>
+<a href="error_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ERROR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ERROR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreement
 s.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comm
 ent"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div>
 <div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160
 ;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno"><a class="line" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">   44</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a>;</div><div class="line"><a name="l00045"></a><span class="linen
 o">   45</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno"><a class="line" href="group__error.html#gac73fbd2363c5f562f85dde459e631394">   46</a></span>&#160;<span class="preprocessor">#define PN_OK (0)              </span></div><div class="line"><a name="l00047"></a><span class="lineno"><a class="line" href="group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3">   47</a></span>&#160;<span class="preprocessor">#define PN_EOS (-1)            </span></div><div class="line"><a name="l00048"></a><span class="lineno"><a class="line" href="group__error.html#ga664f7bdd616c30b72bd50bcc17839c81">   48</a></span>&#160;<span class="preprocessor">#define PN_ERR (-2)            </span></div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7">   49</a></span>&#160;<span class="preprocessor">#define PN_OVERFLOW (-3)       </span></div><div class="line"><a name="l00050"></a><span class="li
 neno"><a class="line" href="group__error.html#ga3317339fb405435df42fa93d62f0e14c">   50</a></span>&#160;<span class="preprocessor">#define PN_UNDERFLOW (-4)      </span></div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="group__error.html#ga5efbe6093556326613d2ccd3864a00aa">   51</a></span>&#160;<span class="preprocessor">#define PN_STATE_ERR (-5)      </span></div><div class="line"><a name="l00052"></a><span class="lineno"><a class="line" href="group__error.html#ga5551b7172de89dc540bd7c2beedd325a">   52</a></span>&#160;<span class="preprocessor">#define PN_ARG_ERR (-6)        </span></div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2">   53</a></span>&#160;<span class="preprocessor">#define PN_TIMEOUT (-7)        </span></div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="group__error.html#ga53284958be0c328f90ca3a4a0793d965"
 >   54</a></span>&#160;<span class="preprocessor">#define PN_INTR (-8)           </span></div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33">   55</a></span>&#160;<span class="preprocessor">#define PN_INPROGRESS (-9)     </span></div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d">   56</a></span>&#160;<span class="preprocessor">#define PN_OUT_OF_MEMORY (-10) </span></div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="group__error.html#ga82db456291c2627e31becc44b733a7f0">   57</a></span>&#160;<span class="preprocessor">#define PN_ABORTED (-11)       </span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor">PN_EXTERN const char *pn_code(int code);</span></div><div class="line"><a name="l00064"></a><span class="lineno
 ">   64</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__error.html#ga0992aa0df5290a2ae639246b0c2f5481">pn_error</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__error.html#ga5e57528759aedb00e68aafd0d025d06c">pn_error_free</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__error.htm
 l#ga15440ed9515967950fa4504a53fc0b64">pn_error_clear</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d">pn_error_set</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *text);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga59db2b3acdca714819c6450d2d5440a1">pn_error_vformat</a>
 (<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list ap);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2">pn_error_format</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error, <span class="keywordtype">int</span> code, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="c
 ode" href="group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c">pn_error_code</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__error.html#ga67cbe6ebb143370e0604f5b84d716c56">pn_error_text</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *error);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3">pn_error_copy</a>(<a class="code" href="group__error.html#ga24a289d5b32c9bd8a77
 5600a5af83d52">pn_error_t</a> *error, <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *src);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">#define PN_RETURN_IF_ERROR(x) \</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">do {\</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;<span class="preprocessor">int r = (x);\</span></div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">if (r &lt; 0) return r; \</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor">} while (0)</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="l
 ine"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;}</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* error.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__error_html_ga96ccb65768c64ee0a1b71b83e08489d3"><div class="ttname"><a href="group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3">pn_error_copy</a></div><div class="ttdeci">int pn_error_copy(pn_error_t *error, pn_error_t *src)</div><div class="ttdoc">Copy the src error. </div></div>
 <div class="ttc" id="group__error_html_gac5b68c9e6a637810a55c0b0e6f66c90d"><div class="ttname"><a href="group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d">pn_error_set</a></div><div class="ttdeci">int pn_error_set(pn_error_t *error, int code, const char *text)</div><div class="ttdoc">Set the error code and text. </div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
 <div class="ttc" id="group__error_html_ga00e179c24bc0954e1f01c64aa832ee2c"><div class="ttname"><a href="group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c">pn_error_code</a></div><div class="ttdeci">int pn_error_code(pn_error_t *error)</div><div class="ttdoc">Get the the error code. </div></div>


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


[11/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/container_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/container_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/container_8hpp_source.html
index 682119d..3ad7e9f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/container_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/container_8hpp_source.html
@@ -93,20 +93,19 @@ $(document).ready(function(){initNavTree('container_8hpp_source.html','');});
 <div class="title">container.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="container_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONTAINER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONTAINER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor l
 icense agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<
 span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for 
 the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="returned_8hpp.html">./returned
 .hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&quot;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include
  &lt;string&gt;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#define PN_CPP_SUPPORTS_THREADS PN_CPP_HAS_STD_THREAD &amp;&amp; PN_CPP_HAS_STD_MUTEX &amp;&amp; PN_CPP_HAS_STD_ATOMIC</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="classproton_1_1container.html">   55</a></span>&#160;<span class="keyword">class </span>PN_CPP_CLASS_EXTERN <a class="code" href="classp
 roton_1_1container.html">container</a> {</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1container.html">container</a>(<a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp; handler, <span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>=<span class="stringliteral">&quot;&quot;</span>);</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN container(<span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>=<span class="stringliteral">&quot;&quot;</span>);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div cla
 ss="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN ~container();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;connection&gt;</a> connect(<span class="keyword">const</span> std::string&amp; conn_url,</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;connection&gt;</a> connect(<span class="
 keyword">const</span> std::string&amp; conn_url);</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url,</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;                                  <a class="code" href="classproton_1_1listen__handler.html">listen_handler</a>&amp; handler);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url,</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;            
                       <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> run();</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">#if PN_CPP_SUPPORTS_THREADS</span></div><div class="line"><a name="l00132"></a><span class=
 "lineno">  132</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> run(<span class="keywordtype">int</span> count);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> auto_stop(<span class="keywordtype">bool</span> enabled);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp; err);</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"
 ><a name="l00167"></a><span class="lineno">  167</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop();</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classpro
 ton_1_1sender__options.html">proton::sender_options</a>&amp; snd_opts);</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::str
 ing&amp; addr_url,</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1sender__options.html">proton::sender_options</a>&amp; snd_opts,</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="
 line"><a name="l00207"></a><span class="lineno">  207</span>&#160;</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>&amp; rcv_opts);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00223"></a><span class="lineno">  223</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00224"></a><span class
 ="lineno">  224</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;</div><div class="line"><a name="l00232"></a><span class="lineno">  232</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>&amp; rcv_opts,</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;                                                   <span class="keyword">const</s
 pan> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;    PN_CPP_EXTERN std::string id() <span class="keyword">const</span>;</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> client_connection_options(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html">connection_optio
 ns</a> client_connection_options() <span class="keyword">const</span>;</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> server_connection_options(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html">connection_options</a> server_connection_options() <span class="keyword">const</span>;</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;</div><div class="line"><a name="l00259"></a><span class="lineno">  259</span>&#160;    PN_CPP_EXTERN <span class="keywor
 dtype">void</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>&amp; snd_opts);</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span>sender_options sender_options() const;</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1receiver__options.html">receiver_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1receiver__options.html">receiver_options</a>&amp; rcv_opts);</div
 ><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span>receiver_options receiver_options() const;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> schedule(<a class="code" href="classproton_1_1duration.html">duration</a> dur, <a class="code" href="classproton_1_1work.html">work</a> fn);</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00280"></a><span class="lineno">  280</span>&#160;    <span class="keyword">class </span>impl;</div><div class="line"><a name="l00281"
 ></a><span class="lineno">  281</span>&#160;    internal::pn_unique_ptr&lt;impl&gt; impl_;</div><div class="line"><a name="l00282"></a><span class="lineno">  282</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1connection__options.html">connection_options</a>;</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1session__options.html">session_options</a>;</div><div class="line"><a name="l00286"></a><span class="lineno">  286</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>receiver_options;</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>sender_optio
 ns;</div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>;</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;};</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;</div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;<span class="preprocessor">#endif // PROTON_CONTAINER_HPP</span></div><div class="ttc" id="returned_8hpp_html"><div class="ttname"><a href="returned_8hpp.html">returned.hpp</a></div><div class="ttdoc">A return type for container methods. </div></div>
-<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
-<div class="ttc" id="classproton_1_1work_html"><div class="ttname"><a href="classproton_1_1work.html">proton::work</a></div><div class="ttdoc">Unsettled API - A work item for a work queue. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:47</div></div>
+<a href="container_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONTAINER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONTAINER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor l
 icense agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<
 span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for 
 the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="returned_8hpp.html">./returned
 .hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&quot;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include
  &lt;string&gt;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="classproton_1_1container.html">   50</a></span>&#160;<span class="keyword">class </span>PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1container.html">container</a> {</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1container.html">con
 tainer</a>(<a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp; handler, <span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN container(<a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp; handler);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN container(<span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>);</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    PN_CPP_EXTERN container();</div><div class="line
 "><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN ~container();</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;connection&gt;</a> connect(<span class="keyword">const</span> std::string&amp; conn_url,</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;    PN_CPP_EXTERN <a class="code" href="classp
 roton_1_1returned.html">returned&lt;connection&gt;</a> connect(<span class="keyword">const</span> std::string&amp; conn_url);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url,</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;                                  <a class="code" href="classproton_1_1listen__handler.html">listen_handler</a>&amp; handler);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url,</div><div class="li
 ne"><a name="l00140"></a><span class="lineno">  140</span>&#160;                                  <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> listen(<span class="keyword">const</span> std::string&amp; listen_url);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> run();</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;<span class="preprocessor">#if PN_CPP_SUPP
 ORTS_THREADS</span></div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> run(<span class="keywordtype">int</span> count);</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> auto_stop(<span class="keywordtype">bool</span> enabled);</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp; err);</div><div class="line"><a name
 ="l00181"></a><span class="lineno">  181</span>&#160;</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop();</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url);</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;                                    
            <span class="keyword">const</span> <a class="code" href="classproton_1_1sender__options.html">proton::sender_options</a>&amp; snd_opts);</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">return
 ed&lt;sender&gt;</a> open_sender(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1sender__options.html">proton::sender_options</a>&amp; snd_opts,</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name="l00232"></a><span class="lineno">  232</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url);</div><div class="line"><a
  name="l00233"></a><span class="lineno">  233</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;</div><div class="line"><a name="l00241"></a><span class="lineno">  241</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>&amp; rcv_opts);</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::s
 tring&amp; addr_url,</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;</div><div class="line"><a name="l00259"></a><span class="lineno">  259</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1returned.html">returned&lt;receiver&gt;</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr_url,</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;                                                   <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>&amp; rcv_opts,</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;     
                                               <span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;</div><div class="line"><a name="l00264"></a><span class="lineno">  264</span>&#160;    PN_CPP_EXTERN std::string id() <span class="keyword">const</span>;</div><div class="line"><a name="l00265"></a><span class="lineno">  265</span>&#160;</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> client_connection_options(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;    PN_CPP_EXTERN <a 
 class="code" href="classproton_1_1connection__options.html">connection_options</a> client_connection_options() <span class="keyword">const</span>;</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> server_connection_options(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; conn_opts);</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;</div><div class="line"><a name="l00281"></a><span class="lineno">  281</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html">connection_options</a> server_connection_options() <span class="keyword">const</span>;</div><div class="line"><a name="l00282"></a><span class="lineno">  282</span>&#160;</div><div class="line"><a name="l00286"></a>
 <span class="lineno">  286</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>&amp; snd_opts);</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;</div><div class="line"><a name="l00289"></a><span class="lineno">  289</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span>sender_options sender_options() const;</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;</div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1receiver__options.html">receiver_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="clas
 sproton_1_1receiver__options.html">receiver_options</a>&amp; rcv_opts);</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span>receiver_options receiver_options() const;</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;</div><div class="line"><a name="l00304"></a><span class="lineno">  304</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> schedule(<a class="code" href="classproton_1_1duration.html">duration</a> dur, work fn);</div><div class="line"><a name="l00305"></a><span class="lineno">  305</span>&#160;</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;    PN_CPP_EXTERN PN_CPP_DEPRECATED(<span class="stringliteral">&quot;Use &#39;container::schedule(duration, work)&#39;&quot;</span>) <span class="keywordtype">void</span> schedule(<a
  class="code" href="classproton_1_1duration.html">duration</a> dur, void_function0&amp; fn);</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;</div><div class="line"><a name="l00310"></a><span class="lineno">  310</span>&#160;    <span class="comment">// This is a hack to ensure that the C++03 version is declared</span></div><div class="line"><a name="l00311"></a><span class="lineno">  311</span>&#160;    <span class="comment">// only during the compilation of the library</span></div><div class="line"><a name="l00312"></a><span class="lineno">  312</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_LAMBDAS &amp;&amp; PN_CPP_HAS_VARIADIC_TEMPLATES &amp;&amp; defined(qpid_proton_cpp_EXPORTS)</span></div><div class="line"><a name="l00313"></a><span class="lineno">  313</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> schedule(<a class="code" href="classproton_1_1duration.html">duration</a> dur, internal::v03::work fn);</div><div c
 lass="line"><a name="l00314"></a><span class="lineno">  314</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00315"></a><span class="lineno">  315</span>&#160;</div><div class="line"><a name="l00317"></a><span class="lineno">  317</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;    <span class="keyword">class </span>impl;</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;    internal::pn_unique_ptr&lt;impl&gt; impl_;</div><div class="line"><a name="l00320"></a><span class="lineno">  320</span>&#160;</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1connection__options.html">connection_options</a>;</div><div class="line"><a name="l00323"></a><span class="lineno">  323</span>&#160;  <span c
 lass="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1session__options.html">session_options</a>;</div><div class="line"><a name="l00324"></a><span class="lineno">  324</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>receiver_options;</div><div class="line"><a name="l00325"></a><span class="lineno">  325</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>sender_options;</div><div class="line"><a name="l00326"></a><span class="lineno">  326</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>;</div><div class="line"><a name="l00328"></a><span class="lineno">  328</span>&#160;};</div><div class="line"><a name="l00329"></a><span class="lineno">  329</span>&#160;</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;} <span class="comment">//
  proton</span></div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;</div><div class="line"><a name="l00332"></a><span class="lineno">  332</span>&#160;<span class="preprocessor">#endif // PROTON_CONTAINER_HPP</span></div><div class="ttc" id="returned_8hpp_html"><div class="ttname"><a href="returned_8hpp.html">returned.hpp</a></div><div class="ttdoc">A return type for container methods. </div></div>
+<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1listener_html"><div class="ttname"><a href="classproton_1_1listener.html">proton::listener</a></div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> listener.hpp:33</div></div>
-<div class="ttc" id="classproton_1_1sender__options_html"><div class="ttname"><a href="classproton_1_1sender__options.html">proton::sender_options</a></div><div class="ttdoc">Options for creating a sender. </div><div class="ttdef"><b>Definition:</b> sender_options.hpp:56</div></div>
+<div class="ttc" id="classproton_1_1sender__options_html"><div class="ttname"><a href="classproton_1_1sender__options.html">proton::sender_options</a></div><div class="ttdoc">Options for creating a sender. </div><div class="ttdef"><b>Definition:</b> sender_options.hpp:57</div></div>
 <div class="ttc" id="classproton_1_1duration_html"><div class="ttname"><a href="classproton_1_1duration.html">proton::duration</a></div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> duration.hpp:39</div></div>
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
-<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:65</div></div>
-<div class="ttc" id="classproton_1_1returned_html"><div class="ttname"><a href="classproton_1_1returned.html">proton::returned</a></div><div class="ttdoc">A return type for container methods. </div><div class="ttdef"><b>Definition:</b> fwd.hpp:69</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:66</div></div>
+<div class="ttc" id="classproton_1_1returned_html"><div class="ttname"><a href="classproton_1_1returned.html">proton::returned</a></div><div class="ttdoc">A return type for container methods. </div><div class="ttdef"><b>Definition:</b> fwd.hpp:79</div></div>
 <div class="ttc" id="types__fwd_8hpp_html"><div class="ttname"><a href="types__fwd_8hpp.html">types_fwd.hpp</a></div><div class="ttdoc">Forward declarations for Proton types used to represent AMQP types. </div></div>
-<div class="ttc" id="classproton_1_1receiver__options_html"><div class="ttname"><a href="classproton_1_1receiver__options.html">proton::receiver_options</a></div><div class="ttdoc">Options for creating a receiver. </div><div class="ttdef"><b>Definition:</b> receiver_options.hpp:55</div></div>
-<div class="ttc" id="classproton_1_1listen__handler_html"><div class="ttname"><a href="classproton_1_1listen__handler.html">proton::listen_handler</a></div><div class="ttdoc">Unsettled API - A handler for incoming connections. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:37</div></div>
-<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:94</div></div>
-<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:61</div></div>
+<div class="ttc" id="classproton_1_1receiver__options_html"><div class="ttname"><a href="classproton_1_1receiver__options.html">proton::receiver_options</a></div><div class="ttdoc">Options for creating a receiver. </div><div class="ttdef"><b>Definition:</b> receiver_options.hpp:56</div></div>
+<div class="ttc" id="classproton_1_1listen__handler_html"><div class="ttname"><a href="classproton_1_1listen__handler.html">proton::listen_handler</a></div><div class="ttdoc">Unsettled API - A handler for incoming connections. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:39</div></div>
+<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:339</div></div>
+<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:62</div></div>
 <div class="ttc" id="classproton_1_1session__options_html"><div class="ttname"><a href="classproton_1_1session__options.html">proton::session_options</a></div><div class="ttdoc">Options for creating a session. </div><div class="ttdef"><b>Definition:</b> session_options.hpp:40</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 <div class="ttc" id="classproton_1_1error__condition_html"><div class="ttname"><a href="classproton_1_1error__condition.html">proton::error_condition</a></div><div class="ttdoc">Describes an endpoint error state. </div><div class="ttdef"><b>Definition:</b> error_condition.hpp:40</div></div>


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


[43/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.html b/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.html
index d3b9cdf..d3b57f9 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.html
@@ -167,7 +167,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <tr class="separator:ga001b2f3c1bfe4d24d53b93d79dccbfe3"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="memItemLeft" align="right" valign="top"><a id="gad0c98415e0105efb71e8c1a8c4c1e5fb"></a>
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *c)</td></tr>
-<tr class="memdesc:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="mdescLeft">&#160;</td><td class="mdescRight">Close both sides side. <br /></td></tr>
+<tr class="memdesc:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="mdescLeft">&#160;</td><td class="mdescRight">Close both sides. <br /></td></tr>
 <tr class="separator:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga00b32ae810a25ba6e172d6ed870982a5"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">pn_connection_driver_next_event</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *)</td></tr>
 <tr class="memdesc:ga00b32ae810a25ba6e172d6ed870982a5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the next event to handle.  <a href="#ga00b32ae810a25ba6e172d6ed870982a5">More...</a><br /></td></tr>
@@ -180,28 +180,31 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <tr class="memdesc:ga38f56836858b2d4a04ab961f650950d4"><td class="mdescLeft">&#160;</td><td class="mdescRight">Return true if the the driver is closed for reading and writing and there are no more events.  <a href="#ga38f56836858b2d4a04ab961f650950d4">More...</a><br /></td></tr>
 <tr class="separator:ga38f56836858b2d4a04ab961f650950d4"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga373eb1f632468582d025f5d6acf9655e"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *name, const char *fmt,...)</td></tr>
-<tr class="memdesc:ga373eb1f632468582d025f5d6acf9655e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set IO error information.  <a href="#ga373eb1f632468582d025f5d6acf9655e">More...</a><br /></td></tr>
+<tr class="memdesc:ga373eb1f632468582d025f5d6acf9655e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set transport error.  <a href="#ga373eb1f632468582d025f5d6acf9655e">More...</a><br /></td></tr>
 <tr class="separator:ga373eb1f632468582d025f5d6acf9655e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad774f90adceaf86748a0ae781f66daf2"><td class="memItemLeft" align="right" valign="top"><a id="gad774f90adceaf86748a0ae781f66daf2"></a>
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *name, const char *fmt, va_list)</td></tr>
-<tr class="memdesc:gad774f90adceaf86748a0ae781f66daf2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set IO error information via a va_list, see <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set IO error information. ">pn_connection_driver_errorf()</a> <br /></td></tr>
+<tr class="memdesc:gad774f90adceaf86748a0ae781f66daf2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set transport error via a va_list, see <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set transport error. ">pn_connection_driver_errorf()</a> <br /></td></tr>
 <tr class="separator:gad774f90adceaf86748a0ae781f66daf2"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gada5c75a658ae2814f253a91723be9baf"><td class="memItemLeft" align="right" valign="top"><a id="gada5c75a658ae2814f253a91723be9baf"></a>
+<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a> (<a class="el" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch)</td></tr>
+<tr class="memdesc:gada5c75a658ae2814f253a91723be9baf"><td class="mdescLeft">&#160;</td><td class="mdescRight">If batch is part of a connection_driver, return the connection_driver address, else return NULL. <br /></td></tr>
+<tr class="separator:gada5c75a658ae2814f253a91723be9baf"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gadb682f03cb66b5898c4b285353e0005e"><td class="memItemLeft" align="right" valign="top"><a id="gadb682f03cb66b5898c4b285353e0005e"></a>
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *msg)</td></tr>
-<tr class="memdesc:gadb682f03cb66b5898c4b285353e0005e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a string message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:gadb682f03cb66b5898c4b285353e0005e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gad603e8d72578bcedd2d9235f74f28f37" title="Log a message using a transport&#39;s logging mechanism. ">pn_transport_log()</a>. <br /></td></tr>
 <tr class="separator:gadb682f03cb66b5898c4b285353e0005e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga756d1d7130b79f639d71d331f9005cab"><td class="memItemLeft" align="right" valign="top"><a id="ga756d1d7130b79f639d71d331f9005cab"></a>
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab">pn_connection_driver_logf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *fmt,...)</td></tr>
-<tr class="memdesc:ga756d1d7130b79f639d71d331f9005cab"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a printf formatted message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:ga756d1d7130b79f639d71d331f9005cab"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84" title="Log a printf formatted message using a transport&#39;s logging mechanism. ">pn_transport_logf()</a>. <br /></td></tr>
 <tr class="separator:ga756d1d7130b79f639d71d331f9005cab"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="memItemLeft" align="right" valign="top"><a id="gabf97a6a0b608fd096fcaa4f2692c2c63"></a>
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *fmt, va_list ap)</td></tr>
-<tr class="memdesc:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a printf formatted message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f" title="Log a printf formatted message using a transport&#39;s logging mechanism. ">pn_transport_vlogf()</a>. <br /></td></tr>
 <tr class="separator:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gada5c75a658ae2814f253a91723be9baf"><td class="memItemLeft" align="right" valign="top"><a id="gada5c75a658ae2814f253a91723be9baf"></a>
-<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a> (<a class="el" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch)</td></tr>
-<tr class="memdesc:gada5c75a658ae2814f253a91723be9baf"><td class="mdescLeft">&#160;</td><td class="mdescRight">If batch is part of a connection_driver, return the connection_driver address, else return NULL. <br /></td></tr>
-<tr class="separator:gada5c75a658ae2814f253a91723be9baf"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> **&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">pn_connection_driver_ptr</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Associate a pn_connection_t with its <a class="el" href="group__connection__driver.html#structpn__connection__driver__t" title="The elements needed to drive AMQP IO and events. ">pn_connection_driver_t</a>.  <a href="#gab9d4f3255c83d7792fc17e5a020ff1c0">More...</a><br /></td></tr>
+<tr class="separator:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <p><b>Unsettled API</b> - An API for low-level IO integration. </p>
@@ -214,7 +217,7 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <p>The <code>pn_connection_driver_*</code> functions provide a simplified API and extra logic to use <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff" title="An AMQP Connection object. ">pn_connection_t</a> and <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8" title="A network channel supporting an AMQP connection. ">pn_transport_t</a> as a unit. You can also access them directly for features that do not have <code>pn_connection_driver_*</code> functions.</p>
 <p>The driver buffers events and data. You should run it until <a class="el" href="group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4" title="Return true if the the driver is closed for reading and writing and there are no more events...">pn_connection_driver_finished()</a> is true, to ensure all reading, writing, and event handling (including <code>ERROR</code> and <code>FINAL</code> events) is finished.</p>
 <h2>Error handling</h2>
-<p>The <code>pn_connection_driver_*</code> functions do not return an error code. IO errors are set on the transport condition and are returned as a <code>PN_TRANSPORT_ERROR</code>. The integration code can set errors using <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set IO error information. ">pn_connection_driver_errorf()</a>.</p>
+<p>The <code>pn_connection_driver_*</code> functions do not return an error code. IO errors are set on the transport condition and are returned as a <code>PN_TRANSPORT_ERROR</code>. The integration code can set errors using <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set transport error. ">pn_connection_driver_errorf()</a>.</p>
 <h2>IO patterns</h2>
 <p>This API supports asynchronous, proactive, non-blocking and reactive IO. An integration does not have to follow the dispatch-read-write sequence above, but note that you should handle all available events before calling <a class="el" href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438" title="Get the read buffer. ">pn_connection_driver_read_buffer()</a> and check that <code>size</code> is non-zero before starting a blocking or asynchronous read call. A <code>read</code> started while there are unprocessed <code>CLOSE</code> events in the buffer may never complete.</p>
 <p>AMQP is a full-duplex, asynchronous protocol. The "read" and "write" sides of an AMQP connection can close separately.</p>
@@ -277,7 +280,7 @@ batch</td>
 </div><div class="memdoc">
 
 <p>The write side of the transport is closed, it will no longer produce bytes to write to external IO. </p>
-<p>Synonynm for PN_TRANSPORT_HEAD_CLOSED </p>
+<p>Synonym for PN_TRANSPORT_HEAD_CLOSED </p>
 
 </div>
 </div>
@@ -294,7 +297,7 @@ batch</td>
 </div><div class="memdoc">
 
 <p>The read side of the transport is closed, it will no longer read bytes from external IO. </p>
-<p>Alisas for PN_TRANSPORT_TAIL_CLOSED </p>
+<p>Alias for PN_TRANSPORT_TAIL_CLOSED </p>
 
 </div>
 </div>
@@ -332,9 +335,9 @@ batch</td>
 </div><div class="memdoc">
 
 <p>Set connection and transport to the provided values, or create a new <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> or <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> if either is NULL. </p>
-<p>The provided values belong to the connection driver and will be freed by <a class="el" href="group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96" title="Unbind, release and free the connection and transport. ">pn_connection_driver_destroy()</a></p>
+<p>The provided values belong to the connection driver and will be freed by <a class="el" href="group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96" title="Unbind, release and free the connection and transport. ">pn_connection_driver_destroy()</a>.</p>
 <p>The transport is bound automatically after the PN_CONNECTION_INIT has been is handled by the application. It can be bound earlier with <a class="el" href="group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56" title="Force binding of the transport. ">pn_connection_driver_bind()</a>.</p>
-<p>The following functions must be called before the transport is bound to have effect: pn_connection_set_username(), <a class="el" href="group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285" title="Set the authentication password for a client connection. ">pn_connection_set_password()</a>, <a class="el" href="group__transport.html#gac5bebd26c0942bc17d7fad36577110f8" title="Configure a transport as a server. ">pn_transport_set_server()</a></p>
+<p>The following functions must be called before the transport is bound to have effect: pn_connection_set_username(), <a class="el" href="group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285" title="Set the authentication password for a client connection. ">pn_connection_set_password()</a>, <a class="el" href="group__transport.html#gac5bebd26c0942bc17d7fad36577110f8" title="Configure a transport as a server. ">pn_transport_set_server()</a>.</p>
 <dl class="section return"><dt>Returns</dt><dd>PN_OUT_OF_MEMORY if any allocation fails. </dd></dl>
 
 </div>
@@ -602,12 +605,35 @@ batch</td>
       </table>
 </div><div class="memdoc">
 
-<p>Set IO error information. </p>
+<p>Set transport error. </p>
 <p>The name and formatted description are set on the transport condition, and returned as a PN_TRANSPORT_ERROR event from <a class="el" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5" title="Get the next event to handle. ">pn_connection_driver_next_event()</a>.</p>
 <p>You must call this <em>before</em> <a class="el" href="group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f" title="Close the read side. ">pn_connection_driver_read_close()</a> or <a class="el" href="group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce" title="Close the write side. ">pn_connection_driver_write_close()</a> to ensure the error is processed. </p>
 
 </div>
 </div>
+<a id="gab9d4f3255c83d7792fc17e5a020ff1c0"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#gab9d4f3255c83d7792fc17e5a020ff1c0">&#9670;&nbsp;</a></span>pn_connection_driver_ptr()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname"><a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a>** pn_connection_driver_ptr </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *&#160;</td>
+          <td class="paramname"><em>connection</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Associate a pn_connection_t with its <a class="el" href="group__connection__driver.html#structpn__connection__driver__t" title="The elements needed to drive AMQP IO and events. ">pn_connection_driver_t</a>. </p>
+<p><b>NOTE</b>: this is only for use by IO integration writers. If you are using the standard pn_proactor_t you <em>must not</em> use this function.</p>
+<dl class="section return"><dt>Returns</dt><dd>pointer to the pn_connection_driver_t* field in a pn_connection_t.</dd></dl>
+<p>Return type is pointer to a pointer so that the caller can (if desired) use atomic operations when loading and storing the value. </p>
+
+</div>
+</div>
 </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.js b/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.js
index ea7ef37..31840dc 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__connection__driver.js
@@ -27,8 +27,9 @@ var group__connection__driver =
     [ "pn_connection_driver_finished", "group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4", null ],
     [ "pn_connection_driver_errorf", "group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e", null ],
     [ "pn_connection_driver_verrorf", "group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2", null ],
+    [ "pn_event_batch_connection_driver", "group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf", null ],
     [ "pn_connection_driver_log", "group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e", null ],
     [ "pn_connection_driver_logf", "group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab", null ],
     [ "pn_connection_driver_vlogf", "group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63", null ],
-    [ "pn_event_batch_connection_driver", "group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf", null ]
+    [ "pn_connection_driver_ptr", "group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__data.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__data.html b/content/releases/qpid-proton-master/proton/c/api/group__data.html
index f61920c..79b9b3e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__data.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__data.html
@@ -118,7 +118,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga68e94dfa5d7ab568425c4a6587bac1db"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error code for a given pn_data_t.  <a href="#ga68e94dfa5d7ab568425c4a6587bac1db">More...</a><br /></td></tr>
 <tr class="separator:ga68e94dfa5d7ab568425c4a6587bac1db"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gada171f4740e6a1132b4d4b9c0aea645c"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">pn_data_error</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
-<tr class="memdesc:gada171f4740e6a1132b4d4b9c0aea645c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error for a givn pn_data_t.  <a href="#gada171f4740e6a1132b4d4b9c0aea645c">More...</a><br /></td></tr>
+<tr class="memdesc:gada171f4740e6a1132b4d4b9c0aea645c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error for a given pn_data_t.  <a href="#gada171f4740e6a1132b4d4b9c0aea645c">More...</a><br /></td></tr>
 <tr class="separator:gada171f4740e6a1132b4d4b9c0aea645c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga7611c1394e80b5166b8b8647659f97e6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#ga7611c1394e80b5166b8b8647659f97e6">pn_data_clear</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
 <tr class="memdesc:ga7611c1394e80b5166b8b8647659f97e6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Clears a pn_data_t object.  <a href="#ga7611c1394e80b5166b8b8647659f97e6">More...</a><br /></td></tr>
@@ -322,7 +322,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:gad03a049653bec28d20dc7587f7e544de"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a symbol, string, or binary, return the bytes representing its value.  <a href="#gad03a049653bec28d20dc7587f7e544de">More...</a><br /></td></tr>
 <tr class="separator:gad03a049653bec28d20dc7587f7e544de"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac5d5c6e6bf24597caf63d35b1755e646"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gac5d5c6e6bf24597caf63d35b1755e646">pn_data_get_atom</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
-<tr class="memdesc:gac5d5c6e6bf24597caf63d35b1755e646"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a>.  <a href="#gac5d5c6e6bf24597caf63d35b1755e646">More...</a><br /></td></tr>
+<tr class="memdesc:gac5d5c6e6bf24597caf63d35b1755e646"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a>.  <a href="#gac5d5c6e6bf24597caf63d35b1755e646">More...</a><br /></td></tr>
 <tr class="separator:gac5d5c6e6bf24597caf63d35b1755e646"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaf0e0fbb9c8c757f94b9636a6b54dc332"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332">pn_data_copy</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data, <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *src)</td></tr>
 <tr class="memdesc:gaf0e0fbb9c8c757f94b9636a6b54dc332"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy the contents of another pn_data_t object.  <a href="#gaf0e0fbb9c8c757f94b9636a6b54dc332">More...</a><br /></td></tr>
@@ -493,8 +493,8 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Access the current error for a givn pn_data_t. </p>
-<p>Every pn_data_t has an error descriptor that is created with the pn_data_t and dies with the pn_data_t. The error descriptor is updated whenever an operation fails. The <a class="el" href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c" title="Access the current error for a givn pn_data_t. ">pn_data_error()</a> function may be used to access a pn_data_t's error descriptor.</p>
+<p>Access the current error for a given pn_data_t. </p>
+<p>Every pn_data_t has an error descriptor that is created with the pn_data_t and dies with the pn_data_t. The error descriptor is updated whenever an operation fails. The <a class="el" href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c" title="Access the current error for a given pn_data_t. ">pn_data_error()</a> function may be used to access a pn_data_t's error descriptor.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
@@ -549,7 +549,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Returns the total number of nodes contained in a pn_data_t object. </p>
-<p>This includes all parents, children, siblings, grandchildren, etc. In other words the count of all ancesters and descendents of the current node, along with the current node if there is one.</p>
+<p>This includes all parents, children, siblings, grandchildren, etc. In other words the count of all ancestors and descendants of the current node, along with the current node if there is one.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
@@ -790,7 +790,7 @@ Functions</h2></td></tr>
   </table>
   </dd>
 </dl>
-<dl class="section return"><dt>Returns</dt><dd>zero on succes, or an error on failure </dd></dl>
+<dl class="section return"><dt>Returns</dt><dd>zero on success, or an error on failure </dd></dl>
 
 </div>
 </div>
@@ -2634,14 +2634,14 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a>. </p>
+<p>If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a>. </p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
   </table>
   </dd>
 </dl>
-<dl class="section return"><dt>Returns</dt><dd>the value of the current node as <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a> </dd></dl>
+<dl class="section return"><dt>Returns</dt><dd>the value of the current node as <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a> </dd></dl>
 
 </div>
 </div>
@@ -2676,7 +2676,7 @@ Functions</h2></td></tr>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
-    <tr><td class="paramname">src</td><td>the sourc pn_data_t to copy from </td></tr>
+    <tr><td class="paramname">src</td><td>the source pn_data_t to copy from </td></tr>
   </table>
   </dd>
 </dl>
@@ -2714,7 +2714,7 @@ Functions</h2></td></tr>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
-    <tr><td class="paramname">src</td><td>the sourc pn_data_t to append from </td></tr>
+    <tr><td class="paramname">src</td><td>the source pn_data_t to append from </td></tr>
   </table>
   </dd>
 </dl>
@@ -2758,7 +2758,7 @@ Functions</h2></td></tr>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramname">data</td><td>a pn_data_t object </td></tr>
-    <tr><td class="paramname">src</td><td>the sourc pn_data_t to append from </td></tr>
+    <tr><td class="paramname">src</td><td>the source pn_data_t to append from </td></tr>
     <tr><td class="paramname">limit</td><td>the maximum number of values to append </td></tr>
   </table>
   </dd>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__delivery.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__delivery.html b/content/releases/qpid-proton-master/proton/c/api/group__delivery.html
index 3556fbc..c2cae00 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__delivery.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__delivery.html
@@ -142,8 +142,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga6a7ef2e317b4ed292cafbb358f0ba6ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a delivery on a link.  <a href="#ga6a7ef2e317b4ed292cafbb358f0ba6ad">More...</a><br /></td></tr>
 <tr class="separator:ga6a7ef2e317b4ed292cafbb358f0ba6ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga17c16f34252597f9e737efae1e2ebb81"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
+<tr class="memdesc:ga17c16f34252597f9e737efae1e2ebb81"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>.  <a href="#ga17c16f34252597f9e737efae1e2ebb81">More...</a><br /></td></tr>
 <tr class="separator:ga17c16f34252597f9e737efae1e2ebb81"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga91519d3e4568ee8b622d3653e20f60a6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery, void *context)</td></tr>
+<tr class="memdesc:ga91519d3e4568ee8b622d3653e20f60a6"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>.  <a href="#ga91519d3e4568ee8b622d3653e20f60a6">More...</a><br /></td></tr>
 <tr class="separator:ga91519d3e4568ee8b622d3653e20f60a6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga3e014fc1759a212bc3ee9e513a274331"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga3e014fc1759a212bc3ee9e513a274331"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a delivery object.  <a href="#ga3e014fc1759a212bc3ee9e513a274331">More...</a><br /></td></tr>
@@ -176,7 +178,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga23c7b3c678228ccb21378e7c8ec9a72d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a delivery only has partial message data.  <a href="#ga23c7b3c678228ccb21378e7c8ec9a72d">More...</a><br /></td></tr>
 <tr class="separator:ga23c7b3c678228ccb21378e7c8ec9a72d"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga712690e0cc84419d7b7ca7c49a10b776"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
-<tr class="memdesc:ga712690e0cc84419d7b7ca7c49a10b776"><td class="mdescLeft">&#160;</td><td class="mdescRight">On the receiving side, check if the delivery has been aborted.  <a href="#ga712690e0cc84419d7b7ca7c49a10b776">More...</a><br /></td></tr>
+<tr class="memdesc:ga712690e0cc84419d7b7ca7c49a10b776"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a received delivery has been aborted.  <a href="#ga712690e0cc84419d7b7ca7c49a10b776">More...</a><br /></td></tr>
 <tr class="separator:ga712690e0cc84419d7b7ca7c49a10b776"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga533bd8dd766786695b6e71f8505252f1"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">pn_delivery_writable</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga533bd8dd766786695b6e71f8505252f1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a delivery is writable.  <a href="#ga533bd8dd766786695b6e71f8505252f1">More...</a><br /></td></tr>
@@ -197,7 +199,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga365b3efbdd225a239dcf4746127c5f33"><td class="mdescLeft">&#160;</td><td class="mdescRight">Return true if delivery is the current delivery for its link.  <a href="#ga365b3efbdd225a239dcf4746127c5f33">More...</a><br /></td></tr>
 <tr class="separator:ga365b3efbdd225a239dcf4746127c5f33"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga407e51ff91368568d15f938b1771357c"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
-<tr class="memdesc:ga407e51ff91368568d15f938b1771357c"><td class="mdescLeft">&#160;</td><td class="mdescRight">On the sending side, abort a delivery.  <a href="#ga407e51ff91368568d15f938b1771357c">More...</a><br /></td></tr>
+<tr class="memdesc:ga407e51ff91368568d15f938b1771357c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Abort a delivery being sent.  <a href="#ga407e51ff91368568d15f938b1771357c">More...</a><br /></td></tr>
 <tr class="separator:ga407e51ff91368568d15f938b1771357c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga98c275fd7158e8b9d7d48d70503d68df"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga98c275fd7158e8b9d7d48d70503d68df"><td class="mdescLeft">&#160;</td><td class="mdescRight">Settle a delivery.  <a href="#ga98c275fd7158e8b9d7d48d70503d68df">More...</a><br /></td></tr>
@@ -489,8 +491,10 @@ least once" semantics.</p>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>. </p>
 <p>Get the application context that is associated with a delivery object.</p>
-<p>The application context for a delivery may be set using <a class="el" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a>.</p>
+<p>The application context for a delivery may be set using <a class="el" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6" title="Deprecated - Use pn_delivery_attachments(). ">pn_delivery_set_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">delivery</td><td>the delivery whose context is to be returned. </td></tr>
@@ -526,8 +530,10 @@ least once" semantics.</p>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>. </p>
 <p>Set a new application context for a delivery object.</p>
-<p>The application context for a delivery object may be retrieved using <a class="el" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a>.</p>
+<p>The application context for a delivery object may be retrieved using <a class="el" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81" title="Deprecated - Use pn_delivery_attachments(). ">pn_delivery_get_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">delivery</td><td>the delivery object </td></tr>
@@ -800,7 +806,7 @@ least once" semantics.</p>
 </div><div class="memdoc">
 
 <p>Check if a delivery only has partial message data. </p>
-<p>Note a partial message may be <a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776" title="On the receiving side, check if the delivery has been aborted. ">pn_delivery_aborted()</a> which means the message is incomplete but the rest of the message will never be delivered.</p>
+<p>The receiver can expect more <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe" title="A delivery has been created or updated. ">PN_DELIVERY</a> events for this delivery containing the remainder of this message.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">delivery</td><td>a delivery object </td></tr>
@@ -827,10 +833,11 @@ least once" semantics.</p>
       </table>
 </div><div class="memdoc">
 
-<p>On the receiving side, check if the delivery has been aborted. </p>
-<p>Aborting a delivery means the sender cannot complete the message. It will not send any more data and the data received so far should be discarded by the receiver. An aborted deliver is settled by the sender.</p>
-<p>Calling <a class="el" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a" title="Receive message data for the current delivery on a link. ">pn_link_recv()</a> when the current delivery on the link is aborted will return a PN_STATE error code.</p>
-<dl class="section see"><dt>See also</dt><dd><a class="el" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c" title="On the sending side, abort a delivery. ">pn_delivery_abort()</a> </dd></dl>
+<p>Check if a received delivery has been aborted. </p>
+<p>An aborted delivery means the sender cannot complete this message and the receiver should discard any data already received. The link remains open for future messages.</p>
+<p>You must still call <a class="el" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df" title="Settle a delivery. ">pn_delivery_settle()</a> to free local resources. An aborted delivery consumes a credit, use <a class="el" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9" title="Grant credit for incoming deliveries on a receiver. ">pn_link_flow()</a> to issue new credit as for a successful delivery.</p>
+<p>Calling <a class="el" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a" title="Receive message data for the current delivery on a link. ">pn_link_recv()</a> when the current delivery is aborted returns <a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0" title="Delivery aborted error. ">PN_ABORTED</a>.</p>
+<dl class="section see"><dt>See also</dt><dd><a class="el" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c" title="Abort a delivery being sent. ">pn_delivery_abort()</a> </dd></dl>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">delivery</td><td>a delivery object </td></tr>
@@ -1033,10 +1040,11 @@ least once" semantics.</p>
       </table>
 </div><div class="memdoc">
 
-<p>On the sending side, abort a delivery. </p>
-<p>Aborting a delivery means the sender cannot complete the message. It will not send any more data and the data received so far should be discarded by the receiver.</p>
-<p>The aborted messages is also settled, and can never be used again.</p>
-<dl class="section see"><dt>See also</dt><dd><a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776" title="On the receiving side, check if the delivery has been aborted. ">pn_delivery_aborted()</a></dd></dl>
+<p>Abort a delivery being sent. </p>
+<p>Aborting means the sender cannot complete this message. It will not send any more data, and data sent so far should be discarded by the receiver. The link remains open for future messages.</p>
+<p>If some data has already been sent on the network, an AMQP "aborted" frame will be sent to inform the peer. If no data has yet been sent, the delivery will simply be forgotten.</p>
+<p>The delivery will be freed, and cannot be used after the call.</p>
+<dl class="section see"><dt>See also</dt><dd><a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776" title="Check if a received delivery has been aborted. ">pn_delivery_aborted()</a></dd></dl>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">delivery</td><td>a delivery object </td></tr>
@@ -1146,7 +1154,7 @@ least once" semantics.</p>
 </div><div class="memdoc">
 
 <p>Extracts the first delivery on the connection that has pending operations. </p>
-<p>Retrieves the first delivery on the Connection that has pending operations. A readable delivery indicates message data is waiting to be read. A writable delivery indicates that message data may be sent. An updated delivery indicates that the delivery's disposition has changed. A delivery will never be both readable and writible, but it may be both readable and updated or both writiable and updated.</p>
+<p>Retrieves the first delivery on the Connection that has pending operations. A readable delivery indicates message data is waiting to be read. A writable delivery indicates that message data may be sent. An updated delivery indicates that the delivery's disposition has changed. A delivery will never be both readable and writable, but it may be both readable and updated or both writable and updated.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>the connection </td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__error.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__error.html b/content/releases/qpid-proton-master/proton/c/api/group__error.html
index 94ce2ec..1e03ec3 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__error.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__error.html
@@ -145,8 +145,12 @@ Macros</h2></td></tr>
 <tr class="separator:gafbb090366e9dbf9a5bb0735df1e23d33"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="memItemLeft" align="right" valign="top"><a id="gab1f773ca03b0953de6ce3caf4c795b8d"></a>
 #define&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d">PN_OUT_OF_MEMORY</a></td></tr>
-<tr class="memdesc:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Out-of-momory error. <br /></td></tr>
+<tr class="memdesc:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Out-of-memory error. <br /></td></tr>
 <tr class="separator:gab1f773ca03b0953de6ce3caf4c795b8d"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga82db456291c2627e31becc44b733a7f0"><td class="memItemLeft" align="right" valign="top"><a id="ga82db456291c2627e31becc44b733a7f0"></a>
+#define&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0">PN_ABORTED</a></td></tr>
+<tr class="memdesc:ga82db456291c2627e31becc44b733a7f0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Delivery aborted error. <br /></td></tr>
+<tr class="separator:ga82db456291c2627e31becc44b733a7f0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="typedef-members"></a>
 Typedefs</h2></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__error.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__error.js b/content/releases/qpid-proton-master/proton/c/api/group__error.js
index 2d7d1c1..b2c7511 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__error.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__error.js
@@ -11,6 +11,7 @@ var group__error =
     [ "PN_INTR", "group__error.html#ga53284958be0c328f90ca3a4a0793d965", null ],
     [ "PN_INPROGRESS", "group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33", null ],
     [ "PN_OUT_OF_MEMORY", "group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d", null ],
+    [ "PN_ABORTED", "group__error.html#ga82db456291c2627e31becc44b733a7f0", null ],
     [ "pn_error_t", "group__error.html#ga24a289d5b32c9bd8a775600a5af83d52", null ],
     [ "pn_code", "group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64", null ],
     [ "pn_error", "group__error.html#ga0992aa0df5290a2ae639246b0c2f5481", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__event.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__event.html b/content/releases/qpid-proton-master/proton/c/api/group__event.html
index 5120623..1c11d08 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__event.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__event.html
@@ -437,7 +437,7 @@ void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="gr
 <tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0"></a>PN_CONNECTION_WAKE&#160;</td><td class="fielddoc"><p><a class="el" href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560" title="Return a PN_CONNECTION_WAKE event for connection as soon as possible. ">pn_connection_wake()</a> was called. </p>
 <p>Events of this type point to the <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>. </p>
 </td></tr>
-<tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c"></a>PN_LISTENER_ACCEPT&#160;</td><td class="fielddoc"><p>Indicates the listener has an incoming connection, call <a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736" title="Bind connection to a new transport accepted from listener. ">pn_listener_accept()</a> to accept it. </p>
+<tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c"></a>PN_LISTENER_ACCEPT&#160;</td><td class="fielddoc"><p>Indicates the listener has an incoming connection, call <a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070" title="Accept an incoming connection request using transport and connection, which can be configured before ...">pn_listener_accept2()</a> to accept it. </p>
 <p>Events of this type point to the <a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>. </p>
 </td></tr>
 <tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca"></a>PN_LISTENER_CLOSE&#160;</td><td class="fielddoc"><p>Indicates the listener has closed. </p>
@@ -453,7 +453,7 @@ void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="gr
 <p>There will be no further events unless new listeners or connections are opened, or a new timeout is set (possibly in other threads in a multi-threaded program.)</p>
 <p>Events of this type point to the <a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a>. </p>
 </td></tr>
-<tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7"></a>PN_LISTENER_OPEN&#160;</td><td class="fielddoc"><p>The listener is listeneing. </p>
+<tr><td class="fieldname"><a id="gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7"></a>PN_LISTENER_OPEN&#160;</td><td class="fielddoc"><p>The listener is listening. </p>
 <p>Events of this type point to the <a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>. </p>
 </td></tr>
 </table>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__link.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__link.html b/content/releases/qpid-proton-master/proton/c/api/group__link.html
index b54b47b..d63f26d 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__link.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__link.html
@@ -133,8 +133,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:gadd3b8899fe023d3506fb88d228d6b1b7"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a link object.  <a href="#gadd3b8899fe023d3506fb88d228d6b1b7">More...</a><br /></td></tr>
 <tr class="separator:gadd3b8899fe023d3506fb88d228d6b1b7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga93e6b527743f433da2ff367c1b2c500a"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
+<tr class="memdesc:ga93e6b527743f433da2ff367c1b2c500a"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>.  <a href="#ga93e6b527743f433da2ff367c1b2c500a">More...</a><br /></td></tr>
 <tr class="separator:ga93e6b527743f433da2ff367c1b2c500a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga376f2cc18bbd771d95aa8222586d19b2"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, void *context)</td></tr>
+<tr class="memdesc:ga376f2cc18bbd771d95aa8222586d19b2"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>.  <a href="#ga376f2cc18bbd771d95aa8222586d19b2">More...</a><br /></td></tr>
 <tr class="separator:ga376f2cc18bbd771d95aa8222586d19b2"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga8b19ffdb7934940fa7c5fd75c5fe2d69"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">pn_link_attachments</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
 <tr class="memdesc:ga8b19ffdb7934940fa7c5fd75c5fe2d69"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a link object.  <a href="#ga8b19ffdb7934940fa7c5fd75c5fe2d69">More...</a><br /></td></tr>
@@ -152,6 +154,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:gad502b38bc184ad0bfaa86dede81f62c9"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the endpoint state flags for a link.  <a href="#gad502b38bc184ad0bfaa86dede81f62c9">More...</a><br /></td></tr>
 <tr class="separator:gad502b38bc184ad0bfaa86dede81f62c9"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
+<tr class="memdesc:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="#gaf6f11d778aa4622d8aa5db8962bb1f0a">More...</a><br /></td></tr>
 <tr class="separator:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga52c99044eabb7712efa2f1098c760804"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga52c99044eabb7712efa2f1098c760804">pn_link_condition</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
 <tr class="memdesc:ga52c99044eabb7712efa2f1098c760804"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local condition associated with a link endpoint.  <a href="#ga52c99044eabb7712efa2f1098c760804">More...</a><br /></td></tr>
@@ -312,7 +315,7 @@ Functions</h2></td></tr>
 </td></tr>
 <tr><td class="fieldname"><a id="gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0"></a>PN_SND_SETTLED&#160;</td><td class="fielddoc"><p>The sender will send all deliveries settled to the receiver. </p>
 </td></tr>
-<tr><td class="fieldname"><a id="gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1"></a>PN_SND_MIXED&#160;</td><td class="fielddoc"><p>The sender may send a mixure of settled and unsettled deliveries. </p>
+<tr><td class="fieldname"><a id="gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1"></a>PN_SND_MIXED&#160;</td><td class="fielddoc"><p>The sender may send a mixture of settled and unsettled deliveries. </p>
 </td></tr>
 </table>
 
@@ -462,8 +465,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>. </p>
 <p>Get the application context that is associated with a link object.</p>
-<p>The application context for a link may be set using <a class="el" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a>.</p>
+<p>The application context for a link may be set using <a class="el" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2" title="Deprecated - Use pn_link_attachments(). ">pn_link_set_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">link</td><td>the link whose context is to be returned. </td></tr>
@@ -499,8 +504,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>. </p>
 <p>Set a new application context for a link object.</p>
-<p>The application context for a link object may be retrieved using <a class="el" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a>.</p>
+<p>The application context for a link object may be retrieved using <a class="el" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a" title="Deprecated - Use pn_link_attachments(). ">pn_link_get_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">link</td><td>the link object </td></tr>
@@ -661,6 +668,8 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> </p>
 <p>Get additional error information associated with the link.</p>
 <p>Whenever a link operation fails (i.e. returns an error code), additional error details can be obtained using this function. The error object that is returned may also be used to clear the error condition.</p>
 <p>The pointer returned by this operation is valid until the link object is freed.</p>
@@ -1759,7 +1768,13 @@ Functions</h2></td></tr>
   </table>
   </dd>
 </dl>
-<dl class="section return"><dt>Returns</dt><dd>the number of bytes received, PN_EOS, or an error code </dd></dl>
+<dl class="section return"><dt>Returns</dt><dd>The number of bytes received, or an error code:<ul>
+<li><a class="el" href="group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3" title="End of stream. ">PN_EOS</a>: The message has been completely received</li>
+<li>0: No data available now. If <a class="el" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d" title="Check if a delivery only has partial message data. ">pn_delivery_partial()</a> there will be further <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe" title="A delivery has been created or updated. ">PN_DELIVERY</a> events with more data.</li>
+<li><a class="el" href="group__error.html#ga5efbe6093556326613d2ccd3864a00aa" title="State error. ">PN_STATE_ERR</a>: The link has no current delivery</li>
+<li><a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0" title="Delivery aborted error. ">PN_ABORTED</a>: See <a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776" title="Check if a received delivery has been aborted. ">pn_delivery_aborted()</a> </li>
+</ul>
+</dd></dl>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__listener.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__listener.html b/content/releases/qpid-proton-master/proton/c/api/group__listener.html
index 978a078..82e898c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__listener.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__listener.html
@@ -115,9 +115,11 @@ Functions</h2></td></tr>
 <tr class="memitem:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">pn_listener_free</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
 <tr class="memdesc:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a listener.  <a href="#gaf5769baf81fdfa80e5c4326dd4a9ab63">More...</a><br /></td></tr>
 <tr class="separator:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gaaee3c3f3822484bc2e370406abf5b736"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *)</td></tr>
-<tr class="memdesc:gaaee3c3f3822484bc2e370406abf5b736"><td class="mdescLeft">&#160;</td><td class="mdescRight">Bind <code>connection</code> to a new transport accepted from <code>listener</code>.  <a href="#gaaee3c3f3822484bc2e370406abf5b736">More...</a><br /></td></tr>
-<tr class="separator:gaaee3c3f3822484bc2e370406abf5b736"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga3719a4ab17b8de42fc6bfb262018d070"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">pn_listener_accept2</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:ga3719a4ab17b8de42fc6bfb262018d070"><td class="mdescLeft">&#160;</td><td class="mdescRight">Accept an incoming connection request using <code>transport</code> and <code>connection</code>, which can be configured before the call.  <a href="#ga3719a4ab17b8de42fc6bfb262018d070">More...</a><br /></td></tr>
+<tr class="separator:ga3719a4ab17b8de42fc6bfb262018d070"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8a100386ab4a079ae6924aeaafc72eb9"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">pn_listener_accept</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="separator:ga8a100386ab4a079ae6924aeaafc72eb9"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaa49d0d11a9f46a75fbbbebf6def2d4b2"><td class="memItemLeft" align="right" valign="top"><a id="gaa49d0d11a9f46a75fbbbebf6def2d4b2"></a>
 PNP_EXTERN <a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
 <tr class="memdesc:gaa49d0d11a9f46a75fbbbebf6def2d4b2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the error condition for a listener. <br /></td></tr>
@@ -183,23 +185,29 @@ PNP_EXTERN <a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad
 
 </div>
 </div>
-<a id="gaaee3c3f3822484bc2e370406abf5b736"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#gaaee3c3f3822484bc2e370406abf5b736">&#9670;&nbsp;</a></span>pn_listener_accept()</h2>
+<a id="ga3719a4ab17b8de42fc6bfb262018d070"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga3719a4ab17b8de42fc6bfb262018d070">&#9670;&nbsp;</a></span>pn_listener_accept2()</h2>
 
 <div class="memitem">
 <div class="memproto">
       <table class="memname">
         <tr>
-          <td class="memname">PNP_EXTERN void pn_listener_accept </td>
+          <td class="memname">PNP_EXTERN void pn_listener_accept2 </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *&#160;</td>
-          <td class="paramname">, </td>
+          <td class="paramname"><em>listener</em>, </td>
         </tr>
         <tr>
           <td class="paramkey"></td>
           <td></td>
           <td class="paramtype"><a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *&#160;</td>
-          <td class="paramname">&#160;</td>
+          <td class="paramname"><em>connection</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
+          <td class="paramname"><em>transport</em>&#160;</td>
         </tr>
         <tr>
           <td></td>
@@ -209,8 +217,46 @@ PNP_EXTERN <a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad
       </table>
 </div><div class="memdoc">
 
-<p>Bind <code>connection</code> to a new transport accepted from <code>listener</code>. </p>
-<p>Errors are returned as <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> events by <a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a>. </p>
+<p>Accept an incoming connection request using <code>transport</code> and <code>connection</code>, which can be configured before the call. </p>
+<p>Call after a <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a> event.</p>
+<p>Errors are returned as <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> events by <a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a>.</p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramdir">[in]</td><td class="paramname">listener</td><td>the listener </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>If NULL a new connection is created. Memory management is the same as for <a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1" title="Connect transport to addr and bind to connection. ">pn_proactor_connect2()</a> </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>If NULL a new transport is created. Memory management is the same as for <a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1" title="Connect transport to addr and bind to connection. ">pn_proactor_connect2()</a> </td></tr>
+  </table>
+  </dd>
+</dl>
+
+</div>
+</div>
+<a id="ga8a100386ab4a079ae6924aeaafc72eb9"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga8a100386ab4a079ae6924aeaafc72eb9">&#9670;&nbsp;</a></span>pn_listener_accept()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN void pn_listener_accept </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *&#160;</td>
+          <td class="paramname"><em>listener</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype"><a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *&#160;</td>
+          <td class="paramname"><em>connection</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000001">Deprecated:</a></b></dt><dd>Use pn_listener_accept2(listener, connection, NULL) </dd></dl>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__listener.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__listener.js b/content/releases/qpid-proton-master/proton/c/api/group__listener.js
index c9383d9..52c2656 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__listener.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__listener.js
@@ -3,7 +3,8 @@ var group__listener =
     [ "pn_listener_t", "group__listener.html#ga68ac7072ae60612d0bca5470014bf216", null ],
     [ "pn_listener", "group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5", null ],
     [ "pn_listener_free", "group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63", null ],
-    [ "pn_listener_accept", "group__listener.html#gaaee3c3f3822484bc2e370406abf5b736", null ],
+    [ "pn_listener_accept2", "group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070", null ],
+    [ "pn_listener_accept", "group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9", null ],
     [ "pn_listener_condition", "group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2", null ],
     [ "pn_listener_attachments", "group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f", null ],
     [ "pn_listener_close", "group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__message.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__message.html b/content/releases/qpid-proton-master/proton/c/api/group__message.html
index 864868d..52bb554 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__message.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__message.html
@@ -258,17 +258,20 @@ Functions</h2></td></tr>
 <tr class="memdesc:gadadb16710eccb6d332d039acc9dc1042"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the annotations for a message.  <a href="#gadadb16710eccb6d332d039acc9dc1042">More...</a><br /></td></tr>
 <tr class="separator:gadadb16710eccb6d332d039acc9dc1042"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg)</td></tr>
-<tr class="memdesc:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the properties for a message.  <a href="#ga43c7ee6ab70316145fb2bb5fcad210ad">More...</a><br /></td></tr>
+<tr class="memdesc:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get and set the properties for a message.  <a href="#ga43c7ee6ab70316145fb2bb5fcad210ad">More...</a><br /></td></tr>
 <tr class="separator:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg)</td></tr>
-<tr class="memdesc:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the body of a message.  <a href="#ga145c06edbcccfbe97136bfb5cb2b22b1">More...</a><br /></td></tr>
+<tr class="memdesc:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get and set the body of a message.  <a href="#ga145c06edbcccfbe97136bfb5cb2b22b1">More...</a><br /></td></tr>
 <tr class="separator:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab0bae90838f4661b0c82c15f25e1e988"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">pn_message_decode</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, const char *bytes, size_t size)</td></tr>
 <tr class="memdesc:gab0bae90838f4661b0c82c15f25e1e988"><td class="mdescLeft">&#160;</td><td class="mdescRight">Decode/load message content from AMQP formatted binary data.  <a href="#gab0bae90838f4661b0c82c15f25e1e988">More...</a><br /></td></tr>
 <tr class="separator:gab0bae90838f4661b0c82c15f25e1e988"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, char *bytes, size_t *size)</td></tr>
-<tr class="memdesc:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode/save message content as AMQP formatted binary data.  <a href="#ga2173bbce3c1f4b04074e42d2fe7da473">More...</a><br /></td></tr>
+<tr class="memdesc:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode a message as AMQP formatted binary data.  <a href="#ga2173bbce3c1f4b04074e42d2fe7da473">More...</a><br /></td></tr>
 <tr class="separator:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">pn_message_send</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <a class="el" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> *buf)</td></tr>
+<tr class="memdesc:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode and send a message on a sender link.  <a href="#ga86cd32577f0e78bab29bd0e49869f0b5">More...</a><br /></td></tr>
+<tr class="separator:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga013d429f94d653bc1e00f1f438a079a6"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga013d429f94d653bc1e00f1f438a079a6">pn_message_data</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
 <tr class="memdesc:ga013d429f94d653bc1e00f1f438a079a6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Save message content into a pn_data_t object data.  <a href="#ga013d429f94d653bc1e00f1f438a079a6">More...</a><br /></td></tr>
 <tr class="separator:ga013d429f94d653bc1e00f1f438a079a6"><td class="memSeparator" colspan="2">&#160;</td></tr>
@@ -872,7 +875,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the id for a message. </p>
-<p>The message id provides a globally unique identifier for a message. A message id can be an a string, an unsigned long, a uuid or a binary value. This operation returns the value of the id using the <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a> descriminated union. See <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a> for details on how to access the value.</p>
+<p>The message id provides a globally unique identifier for a message. A message id can be an a string, an unsigned long, a uuid or a binary value. This operation returns the value of the id using the <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a> discriminated union. See <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a> for details on how to access the value.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">msg</td><td>a message object </td></tr>
@@ -1255,7 +1258,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the correlation id for a message. </p>
-<p>A correlation id can be an a string, an unsigned long, a uuid or a binary value. This operation returns the value of the id using the <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a> descriminated union. See <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a> for details on how to access the value.</p>
+<p>A correlation id can be an a string, an unsigned long, a uuid or a binary value. This operation returns the value of the id using the <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a> discriminated union. See <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a> for details on how to access the value.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">msg</td><td>a message object </td></tr>
@@ -1868,7 +1871,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Get/set the properties for a message. </p>
+<p>Get and set the properties for a message. </p>
 <p>This operation returns a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> representing the content of the properties section of a message. The pointer is valid until the message is freed and may be used to both access and modify the content of the properties section of a message.</p>
 <p>The <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> must either be empty or consist of a string keyed map in order to be considered valid message properties.</p>
 <dl class="params"><dt>Parameters</dt><dd>
@@ -1897,7 +1900,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Get/set the body of a message. </p>
+<p>Get and set the body of a message. </p>
 <p>This operation returns a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> representing the body of a message. The pointer is valid until the message is freed and may be used to both access and modify the content of the message body.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -1987,7 +1990,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Encode/save message content as AMQP formatted binary data. </p>
+<p>Encode a message as AMQP formatted binary data. </p>
 <p>If the buffer space provided is insufficient to store the content held in the message, the operation will fail and return a PN_OVERFLOW error code.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -2002,6 +2005,65 @@ Functions</h2></td></tr>
 
 </div>
 </div>
+<a id="ga86cd32577f0e78bab29bd0e49869f0b5"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga86cd32577f0e78bab29bd0e49869f0b5">&#9670;&nbsp;</a></span>pn_message_send()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">ssize_t pn_message_send </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *&#160;</td>
+          <td class="paramname"><em>msg</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype"><a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *&#160;</td>
+          <td class="paramname"><em>sender</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype"><a class="el" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> *&#160;</td>
+          <td class="paramname"><em>buf</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Encode and send a message on a sender link. </p>
+<p>Performs the following steps:</p><ul>
+<li>create or expand the buffer <code>buf</code> as required</li>
+<li>call <a class="el" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473" title="Encode a message as AMQP formatted binary data. ">pn_message_encode()</a> to encode the message to a buffer</li>
+<li>call <a class="el" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9" title="Send message data for the current delivery on a link. ">pn_link_send()</a> to send the encoded message bytes</li>
+<li>call <a class="el" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f" title="Advance the current delivery of a link to the next delivery on the link. ">pn_link_advance()</a> to indicate the message is complete</li>
+</ul>
+<p>Note: you must create a delivery for the message before calling <a class="el" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5" title="Encode and send a message on a sender link. ">pn_message_send()</a> see <a class="el" href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad" title="Create a delivery on a link. ">pn_delivery()</a></p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramdir">[in]</td><td class="paramname">msg</td><td>A message object. </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">sender</td><td>A sending link. The message will be encoded and sent with <a class="el" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9" title="Send message data for the current delivery on a link. ">pn_link_send()</a> </td></tr>
+    <tr><td class="paramdir">[in,out]</td><td class="paramname">buf</td><td>Used to encode the message.<ul>
+<li>if buf == NULL, temporary space will be allocated and freed with malloc()/free()</li>
+<li>if buf-&gt;start != NULL and buf-&gt;size is large enough, the message is encoded to buf-&gt;start</li>
+<li><p class="startli">if buf-&gt;start == NULL or buf-&gt;size is not enough, the buffer will be extended like this: </p><pre class="fragment">buf-&gt;size = new_size; buf-&gt;start = realloc(buf-&gt;start, new_size)
+</pre><p class="startli">it is possible for the buffer to be extended more than once. </p>
+</li>
+</ul>
+</td></tr>
+  </table>
+  </dd>
+</dl>
+<dl class="section return"><dt>Returns</dt><dd>The number of bytes encoded and sent on success. Returns an error code (&lt; 0) on failure and sets <a class="el" href="group__message.html#ga9ad09178e7682efde76e2d39f352dfe8" title="Access the error information for a message. ">pn_message_error()</a> on msg </dd></dl>
+
+</div>
+</div>
 <a id="ga013d429f94d653bc1e00f1f438a079a6"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#ga013d429f94d653bc1e00f1f438a079a6">&#9670;&nbsp;</a></span>pn_message_data()</h2>
 

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__message.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__message.js b/content/releases/qpid-proton-master/proton/c/api/group__message.js
index 1840c7c..0993d41 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__message.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__message.js
@@ -53,5 +53,6 @@ var group__message =
     [ "pn_message_body", "group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1", null ],
     [ "pn_message_decode", "group__message.html#gab0bae90838f4661b0c82c15f25e1e988", null ],
     [ "pn_message_encode", "group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473", null ],
+    [ "pn_message_send", "group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5", null ],
     [ "pn_message_data", "group__message.html#ga013d429f94d653bc1e00f1f438a079a6", null ]
 ];
\ 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


[42/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__messenger.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__messenger.html b/content/releases/qpid-proton-master/proton/c/api/group__messenger.html
index e9131ce..de5f79b 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__messenger.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__messenger.html
@@ -122,8 +122,9 @@ Typedefs</h2></td></tr>
 <tr class="memitem:ga0d342bb795d48591ad6b3f867766b8b1"><td class="memItemLeft" align="right" valign="top">typedef struct <a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a></td></tr>
 <tr class="memdesc:ga0d342bb795d48591ad6b3f867766b8b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">A <a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1" title="A pn_messenger_t provides a high level interface for sending and receiving messages (See pn_message_t...">pn_messenger_t</a> provides a high level interface for sending and receiving messages (See <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a>).  <a href="#ga0d342bb795d48591ad6b3f867766b8b1">More...</a><br /></td></tr>
 <tr class="separator:ga0d342bb795d48591ad6b3f867766b8b1"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gabd73703511b9dae193765e9e57864291"><td class="memItemLeft" align="right" valign="top">typedef struct <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a></td></tr>
-<tr class="memdesc:gabd73703511b9dae193765e9e57864291"><td class="mdescLeft">&#160;</td><td class="mdescRight">A subscription is a request for incoming messages.  <a href="#gabd73703511b9dae193765e9e57864291">More...</a><br /></td></tr>
+<tr class="memitem:gabd73703511b9dae193765e9e57864291"><td class="memItemLeft" align="right" valign="top"><a id="gabd73703511b9dae193765e9e57864291"></a>
+typedef struct <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a></td></tr>
+<tr class="memdesc:gabd73703511b9dae193765e9e57864291"><td class="mdescLeft">&#160;</td><td class="mdescRight">A subscription is a request for incoming messages. <br /></td></tr>
 <tr class="separator:gabd73703511b9dae193765e9e57864291"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab1173cfe4bcaa0a530c8035dc75f42c7"><td class="memItemLeft" align="right" valign="top"><a id="gab1173cfe4bcaa0a530c8035dc75f42c7"></a>
 typedef int64_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">pn_tracker_t</a></td></tr>
@@ -333,7 +334,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga9be25d57cda5a6e1c5658b0f362c41c7"><td class="mdescLeft">&#160;</td><td class="mdescRight">Gets the remote idle timeout for the specified remote service address.  <a href="#ga9be25d57cda5a6e1c5658b0f362c41c7">More...</a><br /></td></tr>
 <tr class="separator:ga9be25d57cda5a6e1c5658b0f362c41c7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">pn_messenger_set_ssl_peer_authentication_mode</a> (<a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, const <a class="el" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode)</td></tr>
-<tr class="memdesc:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Sets the SSL peer authentiacation mode required when a trust certificate is used.  <a href="#ga59ebaf21eaafaa4b1c359e4284564ff6">More...</a><br /></td></tr>
+<tr class="memdesc:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Sets the SSL peer authentication mode required when a trust certificate is used.  <a href="#ga59ebaf21eaafaa4b1c359e4284564ff6">More...</a><br /></td></tr>
 <tr class="separator:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
@@ -372,14 +373,14 @@ Functions</h2></td></tr>
 <li>amqps://127.0.0.1:1234</li>
 </ul>
 <h1>Sending &amp; Receiving Messages </h1>
-<p>The messenger API works in conjuction with the <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> API. A <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> is a mutable holder of message content.</p>
+<p>The messenger API works in conjunction with the <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> API. A <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> is a mutable holder of message content.</p>
 <p>The <a class="el" href="group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a" title="Puts a message onto the messenger&#39;s outgoing queue. ">pn_messenger_put()</a> operation copies content from the supplied <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> to the outgoing queue, and may send queued messages if it can do so without blocking. The <a class="el" href="group__messenger.html#gae31f9a99dcbedffe83588cf25b805325" title="Send messages from a messenger&#39;s outgoing queue. ">pn_messenger_send()</a> operation blocks until it has sent the requested number of messages, or until a timeout interrupts the attempt.</p>
 <p>pn_messenger_t *messenger = pn_messenger(NULL); pn_message_t *message = <a class="el" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e" title="Construct a new pn_message_t. ">pn_message()</a>; char subject[1024]; for (int i = 0; i &lt; 3; i++) { pn_message_set_address(message, "amqp://host/queue"); sprintf(subject, "Hello World! %i", i); pn_message_set_subject(message, subject); pn_messenger_put(messenger, message) pn_messenger_send(messenger);</p>
 <p>Similarly, the <a class="el" href="group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6" title="Retrieve messages into a messenger&#39;s incoming queue. ">pn_messenger_recv()</a> method receives messages into the incoming queue, and may block as it attempts to receive up to the requested number of messages, or until the timeout is reached. It may receive fewer than the requested number. The <a class="el" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540" title="Get the next message from the head of a messenger&#39;s incoming queue. ">pn_messenger_get()</a> method pops the eldest message off the incoming queue and copies its content into the supplied <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> object. It will not block.</p>
 <p>pn_messenger_t *messenger = pn_messenger(NULL); pn_message_t *message = <a class="el" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e" title="Construct a new pn_message_t. ">pn_message()</a> pn_messenger_recv(messenger): while (pn_messenger_incoming(messenger) &gt; 0) { pn_messenger_get(messenger, message); printf("%s", message.subject); }</p>
 <p>Output: Hello World 0 Hello World 1 Hello World 2</p>
 <p>The blocking flag allows you to turn off blocking behavior entirely, in which case <a class="el" href="group__messenger.html#gae31f9a99dcbedffe83588cf25b805325" title="Send messages from a messenger&#39;s outgoing queue. ">pn_messenger_send()</a> and <a class="el" href="group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6" title="Retrieve messages into a messenger&#39;s incoming queue. ">pn_messenger_recv()</a> will do whatever they can without blocking, and then return. You can then look at the number of incoming and outgoing messages to see how much outstanding work still remains.</p>
-<h1>Authentication Mechanims </h1>
+<h1>Authentication Mechanisms </h1>
 <p>The messenger API authenticates using some specific mechanisms. In prior versions of Proton the only authentication mechanism available was the PLAIN mechanism which transports the user's password over the network unencrypted. The Proton versions 0.10 and newer support other more secure mechanisms which avoid sending the users's password over the network unencrypted. For backwards compatibility the 0.10 version of the messenger API will also allow the use of the unencrypted PLAIN mechanism. From the 0.11 version and onwards you will need to set the flag PN_FLAGS_ALLOW_INSECURE_MECHS to carry on using the unencrypted PLAIN mechanism.</p>
 <p>The code for this looks like:</p>
 <p>... pn_messenger_set_flags(messenger, PN_FLAGS_ALLOW_INSECURE_MECHS); ...</p>
@@ -387,22 +388,6 @@ Functions</h2></td></tr>
 
 </div>
 </div>
-<a id="gabd73703511b9dae193765e9e57864291"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#gabd73703511b9dae193765e9e57864291">&#9670;&nbsp;</a></span>pn_subscription_t</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname">typedef struct <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-<p>A subscription is a request for incoming messages. </p>
-
-</div>
-</div>
 <h2 class="groupheader">Enumeration Type Documentation</h2>
 <a id="ga242e4ee54b9c0a416443c7da5f6e045b"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#ga242e4ee54b9c0a416443c7da5f6e045b">&#9670;&nbsp;</a></span>pn_status_t</h2>
@@ -1922,7 +1907,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the next message from the head of a messenger's incoming queue. </p>
-<p>The get operation copies the message data from the head of the messenger's incoming queue into the provided <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> object. If provided <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> pointer is NULL, the head essage will be discarded. This operation will return <a class="el" href="group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3" title="End of stream. ">PN_EOS</a> if there are no messages left on the incoming queue.</p>
+<p>The get operation copies the message data from the head of the messenger's incoming queue into the provided <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> object. If provided <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a> pointer is NULL, the head message will be discarded. This operation will return <a class="el" href="group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3" title="End of stream. ">PN_EOS</a> if there are no messages left on the incoming queue.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">messenger</td><td>a messenger object </td></tr>
@@ -1980,7 +1965,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the subscription of the message most recently retrieved by <a class="el" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540" title="Get the next message from the head of a messenger&#39;s incoming queue. ">pn_messenger_get()</a>. </p>
-<p>This operation will return NULL if <a class="el" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540" title="Get the next message from the head of a messenger&#39;s incoming queue. ">pn_messenger_get()</a> has never been succesfully called.</p>
+<p>This operation will return NULL if <a class="el" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540" title="Get the next message from the head of a messenger&#39;s incoming queue. ">pn_messenger_get()</a> has never been successfully called.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">messenger</td><td>a messenger object </td></tr>
@@ -2591,7 +2576,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Sets the SSL peer authentiacation mode required when a trust certificate is used. </p>
+<p>Sets the SSL peer authentication mode required when a trust certificate is used. </p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">messenger</td><td>a messenger object </td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__proactor.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__proactor.html b/content/releases/qpid-proton-master/proton/c/api/group__proactor.html
index f5fd17c..b2eb3e6 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__proactor.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__proactor.html
@@ -122,22 +122,36 @@ typedef struct <a class="el" href="group__proactor.html#gabba42c7929dfceb9d29653
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="func-members"></a>
 Functions</h2></td></tr>
 <tr class="memitem:ga9f6a27999303c6082edc581f880de37c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *addr, char *buf, size_t size)</td></tr>
-<tr class="memdesc:ga9f6a27999303c6082edc581f880de37c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a network address as a human-readable string in <code>buf</code>.  <a href="#ga9f6a27999303c6082edc581f880de37c">More...</a><br /></td></tr>
+<tr class="memdesc:ga9f6a27999303c6082edc581f880de37c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a network address string in <code>buf</code>.  <a href="#ga9f6a27999303c6082edc581f880de37c">More...</a><br /></td></tr>
 <tr class="separator:ga9f6a27999303c6082edc581f880de37c"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
-<tr class="memdesc:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="#ga7edab5e295c55e1c2169e39aaa082f8b">More...</a><br /></td></tr>
-<tr class="separator:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
-<tr class="memdesc:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the remote address of a transport.  <a href="#ga59fa5ba7adc39bc8549645d5d33082c0">More...</a><br /></td></tr>
-<tr class="separator:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8bcff2f30c1608c1d883eab461cc9148"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">pn_transport_local_addr</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="memdesc:ga8bcff2f30c1608c1d883eab461cc9148"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="#ga8bcff2f30c1608c1d883eab461cc9148">More...</a><br /></td></tr>
+<tr class="separator:ga8bcff2f30c1608c1d883eab461cc9148"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga3a6d4bda7cfae2780dbb587443eded39"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">pn_transport_remote_addr</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="memdesc:ga3a6d4bda7cfae2780dbb587443eded39"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="#ga3a6d4bda7cfae2780dbb587443eded39">More...</a><br /></td></tr>
+<tr class="separator:ga3a6d4bda7cfae2780dbb587443eded39"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">pn_listener_addr</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
+<tr class="memdesc:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the listening addresses of a listener.  <a href="#gacdbda4ea3dc040af5a4c1d633ddd7cd9">More...</a><br /></td></tr>
+<tr class="separator:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga6163449ac3b87782628448f192930eb0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
+<tr class="separator:ga6163449ac3b87782628448f192930eb0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const struct sockaddr *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">pn_netaddr_sockaddr</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
 <tr class="memdesc:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="mdescLeft">&#160;</td><td class="mdescRight">On POSIX or Windows, get the underlying <code>struct sockaddr</code>.  <a href="#ga00b1a40af2d837915d21cdb52ccb0c58">More...</a><br /></td></tr>
 <tr class="separator:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN size_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">pn_netaddr_socklen</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
 <tr class="memdesc:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="mdescLeft">&#160;</td><td class="mdescRight">On POSIX or Windows, get the size of the underlying <code>struct sockaddr</code>.  <a href="#gaddaf2b0b3e107d100e4c3658116a6c3c">More...</a><br /></td></tr>
 <tr class="separator:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">pn_netaddr_host_port</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na, char *host, size_t hlen, char *port, size_t plen)</td></tr>
+<tr class="memdesc:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the host and port name from na as separate strings.  <a href="#ga8cdeab8554e7d376a422dae8ac6d474b">More...</a><br /></td></tr>
+<tr class="separator:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="separator:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="separator:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga955471a53dd486a6f227d8d57322a44c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">pn_netaddr_listening</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
+<tr class="separator:ga955471a53dd486a6f227d8d57322a44c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaf67a7642c9003b36255b58776b494c96"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a> (char *addr, size_t size, const char *host, const char *port)</td></tr>
-<tr class="memdesc:gaf67a7642c9003b36255b58776b494c96"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6" title="Bind connection to a new Transport connected to addr. ">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>  <a href="#gaf67a7642c9003b36255b58776b494c96">More...</a><br /></td></tr>
+<tr class="memdesc:gaf67a7642c9003b36255b58776b494c96"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>  <a href="#gaf67a7642c9003b36255b58776b494c96">More...</a><br /></td></tr>
 <tr class="separator:gaf67a7642c9003b36255b58776b494c96"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac2a925b3de00efd8cd40fa9920169554"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN <a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a> (void)</td></tr>
 <tr class="memdesc:gac2a925b3de00efd8cd40fa9920169554"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a proactor.  <a href="#gac2a925b3de00efd8cd40fa9920169554">More...</a><br /></td></tr>
@@ -145,8 +159,10 @@ Functions</h2></td></tr>
 <tr class="memitem:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor)</td></tr>
 <tr class="memdesc:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free the proactor.  <a href="#ga5260c2653d4af5eb2f1c8c6190e9d6cf">More...</a><br /></td></tr>
 <tr class="separator:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gabb093e51449351cf5530bb300bd67ba1"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">pn_proactor_connect2</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *addr)</td></tr>
+<tr class="memdesc:gabb093e51449351cf5530bb300bd67ba1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Connect <code>transport</code> to <code>addr</code> and bind to <code>connection</code>.  <a href="#gabb093e51449351cf5530bb300bd67ba1">More...</a><br /></td></tr>
+<tr class="separator:gabb093e51449351cf5530bb300bd67ba1"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, const char *addr)</td></tr>
-<tr class="memdesc:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Bind <code>connection</code> to a new <a class="el" href="group__transport.html">Transport</a> connected to <code>addr</code>.  <a href="#ga9a9d1c4138226fa87160f4769b87f8e6">More...</a><br /></td></tr>
 <tr class="separator:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gacbed6a4ab75ef8452c10d52e4cd62752"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, const char *addr, int backlog)</td></tr>
 <tr class="memdesc:gacbed6a4ab75ef8452c10d52e4cd62752"><td class="mdescLeft">&#160;</td><td class="mdescRight">Start listening for incoming connections.  <a href="#gacbed6a4ab75ef8452c10d52e4cd62752">More...</a><br /></td></tr>
@@ -231,19 +247,19 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Format a network address as a human-readable string in <code>buf</code>. </p>
+<p>Format a network address string in <code>buf</code>. </p>
 <dl class="section return"><dt>Returns</dt><dd>the length of the string (excluding trailing '\0'), if &gt;= size then the address was truncated. </dd></dl>
 
 </div>
 </div>
-<a id="ga7edab5e295c55e1c2169e39aaa082f8b"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ga7edab5e295c55e1c2169e39aaa082f8b">&#9670;&nbsp;</a></span>pn_netaddr_local()</h2>
+<a id="ga8bcff2f30c1608c1d883eab461cc9148"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga8bcff2f30c1608c1d883eab461cc9148">&#9670;&nbsp;</a></span>pn_transport_local_addr()</h2>
 
 <div class="memitem">
 <div class="memproto">
       <table class="memname">
         <tr>
-          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_local </td>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_transport_local_addr </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
           <td class="paramname"><em>t</em></td><td>)</td>
@@ -253,18 +269,18 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the local address of a transport. </p>
-<p>Return <code>NULL</code> if not available. </p>
+<p>Return <code>NULL</code> if not available. Pointer is invalid after the transport closes (PN_TRANSPORT_CLOSED event is handled) </p>
 
 </div>
 </div>
-<a id="ga59fa5ba7adc39bc8549645d5d33082c0"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ga59fa5ba7adc39bc8549645d5d33082c0">&#9670;&nbsp;</a></span>pn_netaddr_remote()</h2>
+<a id="ga3a6d4bda7cfae2780dbb587443eded39"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga3a6d4bda7cfae2780dbb587443eded39">&#9670;&nbsp;</a></span>pn_transport_remote_addr()</h2>
 
 <div class="memitem">
 <div class="memproto">
       <table class="memname">
         <tr>
-          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_remote </td>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_transport_remote_addr </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
           <td class="paramname"><em>t</em></td><td>)</td>
@@ -273,8 +289,61 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Get the remote address of a transport. </p>
-<p>Return NULL if not available. </p>
+<p>Get the local address of a transport. </p>
+<p>Return <code>NULL</code> if not available. Pointer is invalid after the transport closes (PN_TRANSPORT_CLOSED event is handled) </p>
+
+</div>
+</div>
+<a id="gacdbda4ea3dc040af5a4c1d633ddd7cd9"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#gacdbda4ea3dc040af5a4c1d633ddd7cd9">&#9670;&nbsp;</a></span>pn_listener_addr()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_listener_addr </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *&#160;</td>
+          <td class="paramname"><em>l</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Get the listening addresses of a listener. </p>
+<p>Addresses are only available after the <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a> event for the listener.</p>
+<p>A listener can have more than one address for several reasons:</p><ul>
+<li>DNS host records may indicate more than one address</li>
+<li>On a multi-homed host, listening on the default host "" will listen on all local addresses.</li>
+<li>Some IPv4/IPV6 configurations may expand a single address into a v4/v6 pair.</li>
+</ul>
+<p><a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next()</a> will iterate over the addresses in the list.</p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramname">l</td><td>points to the listener </td></tr>
+  </table>
+  </dd>
+</dl>
+<dl class="section return"><dt>Returns</dt><dd>The first listening address or NULL if there are no addresses are available. Use <a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next()</a> to iterate over the list. Pointer is invalid after the listener closes (PN_LISTENER_CLOSED event is handled) </dd></dl>
+
+</div>
+</div>
+<a id="ga6163449ac3b87782628448f192930eb0"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga6163449ac3b87782628448f192930eb0">&#9670;&nbsp;</a></span>pn_netaddr_next()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_next </td>
+          <td>(</td>
+          <td class="paramtype">const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td>
+          <td class="paramname"><em>na</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="section return"><dt>Returns</dt><dd>Pointer to the next address in a list of addresses, NULL if at the end of the list or if this address is not part of a list. </dd></dl>
 
 </div>
 </div>
@@ -320,6 +389,112 @@ Functions</h2></td></tr>
 
 </div>
 </div>
+<a id="ga8cdeab8554e7d376a422dae8ac6d474b"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga8cdeab8554e7d376a422dae8ac6d474b">&#9670;&nbsp;</a></span>pn_netaddr_host_port()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN int pn_netaddr_host_port </td>
+          <td>(</td>
+          <td class="paramtype">const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td>
+          <td class="paramname"><em>na</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">char *&#160;</td>
+          <td class="paramname"><em>host</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">size_t&#160;</td>
+          <td class="paramname"><em>hlen</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">char *&#160;</td>
+          <td class="paramname"><em>port</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">size_t&#160;</td>
+          <td class="paramname"><em>plen</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Get the host and port name from na as separate strings. </p>
+<p>Returns 0 if successful, non-0 on error. </p>
+
+</div>
+</div>
+<a id="ga7edab5e295c55e1c2169e39aaa082f8b"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga7edab5e295c55e1c2169e39aaa082f8b">&#9670;&nbsp;</a></span>pn_netaddr_local()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_local </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
+          <td class="paramname"><em>t</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000002">Deprecated:</a></b></dt><dd>Use pn_transport_local_addr </dd></dl>
+
+</div>
+</div>
+<a id="ga59fa5ba7adc39bc8549645d5d33082c0"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga59fa5ba7adc39bc8549645d5d33082c0">&#9670;&nbsp;</a></span>pn_netaddr_remote()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_remote </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
+          <td class="paramname"><em>t</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000003">Deprecated:</a></b></dt><dd>Use <a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39" title="Get the local address of a transport. ">pn_transport_remote_addr()</a> </dd></dl>
+
+</div>
+</div>
+<a id="ga955471a53dd486a6f227d8d57322a44c"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga955471a53dd486a6f227d8d57322a44c">&#9670;&nbsp;</a></span>pn_netaddr_listening()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* pn_netaddr_listening </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *&#160;</td>
+          <td class="paramname"><em>l</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000004">Deprecated:</a></b></dt><dd>Use <a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9" title="Get the listening addresses of a listener. ">pn_listener_addr()</a> </dd></dl>
+
+</div>
+</div>
 <a id="gaf67a7642c9003b36255b58776b494c96"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#gaf67a7642c9003b36255b58776b494c96">&#9670;&nbsp;</a></span>pn_proactor_addr()</h2>
 
@@ -358,7 +533,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6" title="Bind connection to a new Transport connected to addr. ">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a> </p>
+<p>Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a> </p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[out]</td><td class="paramname">addr</td><td>address is copied to this buffer, with trailing '\0' </td></tr>
@@ -414,14 +589,14 @@ Functions</h2></td></tr>
 
 </div>
 </div>
-<a id="ga9a9d1c4138226fa87160f4769b87f8e6"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ga9a9d1c4138226fa87160f4769b87f8e6">&#9670;&nbsp;</a></span>pn_proactor_connect()</h2>
+<a id="gabb093e51449351cf5530bb300bd67ba1"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#gabb093e51449351cf5530bb300bd67ba1">&#9670;&nbsp;</a></span>pn_proactor_connect2()</h2>
 
 <div class="memitem">
 <div class="memproto">
       <table class="memname">
         <tr>
-          <td class="memname">PNP_EXTERN void pn_proactor_connect </td>
+          <td class="memname">PNP_EXTERN void pn_proactor_connect2 </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *&#160;</td>
           <td class="paramname"><em>proactor</em>, </td>
@@ -435,6 +610,12 @@ Functions</h2></td></tr>
         <tr>
           <td class="paramkey"></td>
           <td></td>
+          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
+          <td class="paramname"><em>transport</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
           <td class="paramtype">const char *&#160;</td>
           <td class="paramname"><em>addr</em>&#160;</td>
         </tr>
@@ -446,21 +627,56 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Bind <code>connection</code> to a new <a class="el" href="group__transport.html">Transport</a> connected to <code>addr</code>. </p>
+<p>Connect <code>transport</code> to <code>addr</code> and bind to <code>connection</code>. </p>
 <p>Errors are returned as <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> events by <a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a>.</p>
 <dl class="section note"><dt>Note</dt><dd>Thread-safe</dd></dl>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">proactor</td><td>the proactor object</td></tr>
-    <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td><code>proactor</code> <em>takes ownership</em> of <code>connection</code> and will automatically call <a class="el" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e" title="Free a connection object. ">pn_connection_free()</a> after the final <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> event is handled, or when <a class="el" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf" title="Free the proactor. ">pn_proactor_free()</a> is called. You can prevent the automatic free with <a class="el" href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27" title="Release ownership of connection, disassociate it from its proactor. ">pn_proactor_release_connection()</a></td></tr>
-    <tr><td class="paramdir">[in]</td><td class="paramname">addr</td><td>the "host:port" network address, constructed by <a class="el" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96" title="Format a host:port address string for pn_proactor_connect() or pn_proactor_listen() ...">pn_proactor_addr()</a> An empty host will connect to the local host via the default protocol (IPV6 or IPV4). An empty port will connect to the standard AMQP port (5672).</td></tr>
-    <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td><a class="el" href="group__connection.html">Connection</a> to be connected to <code>addr</code>. </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>If NULL a new connection is created. <code>proactor</code> <em>takes ownership</em> of <code>connection</code> and will automatically call <a class="el" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e" title="Free a connection object. ">pn_connection_free()</a> after the final <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> event is handled, or when <a class="el" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf" title="Free the proactor. ">pn_proactor_free()</a> is called. You can prevent the automatic free with <a class="el" href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27" title="Release ownership of connection, disassociate it from its proactor. ">pn_proactor_release_connection()</a></td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>If NULL a new transport is created. <code>proactor</code> <em>takes ownership</em> of <code>transport</code>, it will be freed even if <a class="el" href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27" title="Release ownership of connection, disassociate it from its proactor. ">pn_proactor_release_connection()</a> is called.</td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">addr</td><td>the "host:port" network address, constructed by <a class="el" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96" title="Format a host:port address string for pn_proactor_connect() or pn_proactor_listen() ...">pn_proactor_addr()</a> An empty host will connect to the local host via the default protocol (IPV6 or IPV4). An empty port will connect to the standard AMQP port (5672). </td></tr>
   </table>
   </dd>
 </dl>
 
 </div>
 </div>
+<a id="ga9a9d1c4138226fa87160f4769b87f8e6"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga9a9d1c4138226fa87160f4769b87f8e6">&#9670;&nbsp;</a></span>pn_proactor_connect()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">PNP_EXTERN void pn_proactor_connect </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *&#160;</td>
+          <td class="paramname"><em>proactor</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype"><a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *&#160;</td>
+          <td class="paramname"><em>connection</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">const char *&#160;</td>
+          <td class="paramname"><em>addr</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000005">Deprecated:</a></b></dt><dd>Use pn_proactor_connect2(proactor, connection, NULL, addr) </dd></dl>
+
+</div>
+</div>
 <a id="gacbed6a4ab75ef8452c10d52e4cd62752"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#gacbed6a4ab75ef8452c10d52e4cd62752">&#9670;&nbsp;</a></span>pn_proactor_listen()</h2>
 
@@ -500,7 +716,8 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Start listening for incoming connections. </p>
-<p>Errors are returned as <a class="el" href="group__proactor__events.html">Proactor events</a> by <a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a>.</p>
+<p><a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a> will return a <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a> event when the listener is ready to accept connections, or a PN_LISTENER_CLOSE if the listen operation fails. If the listen failed, <a class="el" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2" title="Get the error condition for a listener. ">pn_listener_condition()</a> will be set.</p>
+<p>When the listener is closed by <a class="el" href="group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104" title="Close the listener. ">pn_listener_close()</a>, or because of an error, a PN_LISTENER_CLOSE event will be returned and <a class="el" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2" title="Get the error condition for a listener. ">pn_listener_condition()</a> will be set for an error.</p>
 <dl class="section note"><dt>Note</dt><dd>Thread-safe</dd></dl>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -542,8 +759,8 @@ Functions</h2></td></tr>
 
 <p>Disconnect all connections and listeners belonging to the proactor. </p>
 <p><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca">PN_LISTENER_CLOSE</a>, <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> and other <a class="el" href="group__proactor__events.html">Proactor events</a> are generated as usual.</p>
-<p>If no new listeners or connections are created, then a <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a> event will be generated when all connections and listeners are disconnected and no timeout is pending - see <a class="el" href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32" title="Return a PN_PROACTOR_TIMEOUT after timeout milliseconds elapse. ">pn_proactor_set_timeout()</a> <a class="el" href="group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f" title="Cancel the pending timeout set by pn_proactor_set_timeout(). ">pn_proactor_cancel_timeout()</a></p>
-<p>Note the proactor remains active, connections and listeners created after a call to <a class="el" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68" title="Disconnect all connections and listeners belonging to the proactor. ">pn_proactor_disconnect()</a> are not affected by it.</p>
+<p>A <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a> event will be generated when all connections and listeners are disconnected and no timeout is pending. The event will also be generated if there are no listeners, connections or timeout when <a class="el" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68" title="Disconnect all connections and listeners belonging to the proactor. ">pn_proactor_disconnect()</a> is called.</p>
+<p>Creating new connections and listeners after this call and before the PN_PROACTOR_INACTIVE event may prevent the proactor from becoming inactive. After the PN_PROACTOR_INACTIVE event, the proactor can be used normally.</p>
 <dl class="section note"><dt>Note</dt><dd>Thread-safe</dd></dl>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -684,7 +901,7 @@ Functions</h2></td></tr>
 
 <p>Return a <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe">PN_PROACTOR_TIMEOUT</a> after <code>timeout</code> milliseconds elapse. </p>
 <p>If no threads are blocked in <a class="el" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d" title="Wait until there are Proactor events to handle. ">pn_proactor_wait()</a> when the timeout elapses, the event will be delivered to the next available thread.</p>
-<p>Calling <a class="el" href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32" title="Return a PN_PROACTOR_TIMEOUT after timeout milliseconds elapse. ">pn_proactor_set_timeout()</a> again before the PN_PROACTOR_TIMEOUT is delivered will cancel the previous timeout and deliver an event only after the new timeout.</p>
+<p>Calling <a class="el" href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32" title="Return a PN_PROACTOR_TIMEOUT after timeout milliseconds elapse. ">pn_proactor_set_timeout()</a> again before the PN_PROACTOR_TIMEOUT is delivered replaces the previous timeout value.</p>
 <dl class="section note"><dt>Note</dt><dd>Thread-safe </dd></dl>
 
 </div>
@@ -728,7 +945,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Release ownership of <code>connection</code>, disassociate it from its proactor. </p>
-<p>The connection and related objects (<a class="el" href="group__session.html">sessions</a>, <a class="el" href="group__link.html">links</a> and so on) remain intact, but the transport is closed and unbound. The proactor will not return any more events for this connection. The caller must call <a class="el" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e" title="Free a connection object. ">pn_connection_free()</a>, either directly or indirectly by re-using <code>connection</code> in another call to <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6" title="Bind connection to a new Transport connected to addr. ">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>.</p>
+<p>The connection and related objects (<a class="el" href="group__session.html">sessions</a>, <a class="el" href="group__link.html">links</a> and so on) remain intact, but the transport is closed and unbound. The proactor will not return any more events for this connection. The caller must call <a class="el" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e" title="Free a connection object. ">pn_connection_free()</a>, either directly or indirectly by re-using <code>connection</code> in another call to <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>.</p>
 <dl class="section note"><dt>Note</dt><dd><b>Not thread-safe</b>. Call this function from a connection event handler.</dd>
 <dd>
 If <code>connection</code> does not belong to a proactor, this call does nothing.</dd>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__proactor.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__proactor.js b/content/releases/qpid-proton-master/proton/c/api/group__proactor.js
index 5cfcb1a..3eaa04c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__proactor.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__proactor.js
@@ -4,13 +4,20 @@ var group__proactor =
     [ "pn_netaddr_t", "group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c", null ],
     [ "pn_proactor_t", "group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc", null ],
     [ "pn_netaddr_str", "group__proactor.html#ga9f6a27999303c6082edc581f880de37c", null ],
-    [ "pn_netaddr_local", "group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b", null ],
-    [ "pn_netaddr_remote", "group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0", null ],
+    [ "pn_transport_local_addr", "group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148", null ],
+    [ "pn_transport_remote_addr", "group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39", null ],
+    [ "pn_listener_addr", "group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9", null ],
+    [ "pn_netaddr_next", "group__proactor.html#ga6163449ac3b87782628448f192930eb0", null ],
     [ "pn_netaddr_sockaddr", "group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58", null ],
     [ "pn_netaddr_socklen", "group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c", null ],
+    [ "pn_netaddr_host_port", "group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b", null ],
+    [ "pn_netaddr_local", "group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b", null ],
+    [ "pn_netaddr_remote", "group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0", null ],
+    [ "pn_netaddr_listening", "group__proactor.html#ga955471a53dd486a6f227d8d57322a44c", null ],
     [ "pn_proactor_addr", "group__proactor.html#gaf67a7642c9003b36255b58776b494c96", null ],
     [ "pn_proactor", "group__proactor.html#gac2a925b3de00efd8cd40fa9920169554", null ],
     [ "pn_proactor_free", "group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf", null ],
+    [ "pn_proactor_connect2", "group__proactor.html#gabb093e51449351cf5530bb300bd67ba1", null ],
     [ "pn_proactor_connect", "group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6", null ],
     [ "pn_proactor_listen", "group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752", null ],
     [ "pn_proactor_disconnect", "group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__proactor__events.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__proactor__events.html b/content/releases/qpid-proton-master/proton/c/api/group__proactor__events.html
index 3da8e6e..662770e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__proactor__events.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__proactor__events.html
@@ -163,9 +163,9 @@ $(document).ready(function(){initNavTree('group__proactor__events.html','');});
 <tr>
 <td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a> </td><td align="left">The final event for a proactor connection, the transport is closed. </td></tr>
 <tr>
-<td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a> </td><td align="left">The listener is listeneing. </td></tr>
+<td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a> </td><td align="left">The listener is listening. </td></tr>
 <tr>
-<td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a> </td><td align="left">Indicates the listener has an incoming connection, call <a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736" title="Bind connection to a new transport accepted from listener. ">pn_listener_accept()</a> to accept it. </td></tr>
+<td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a> </td><td align="left">Indicates the listener has an incoming connection, call <a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070" title="Accept an incoming connection request using transport and connection, which can be configured before ...">pn_listener_accept2()</a> to accept it. </td></tr>
 <tr>
 <td align="left"><a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca">PN_LISTENER_CLOSE</a> </td><td align="left">Indicates the listener has closed. </td></tr>
 <tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__sasl.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__sasl.html b/content/releases/qpid-proton-master/proton/c/api/group__sasl.html
index 1d98dec..781bb4e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__sasl.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__sasl.html
@@ -133,8 +133,9 @@ Functions</h2></td></tr>
 <tr class="memitem:ga0199871440c4ff89a204cc1d8a09f283"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283">pn_sasl_done</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a> outcome)</td></tr>
 <tr class="memdesc:ga0199871440c4ff89a204cc1d8a09f283"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set the outcome of SASL negotiation.  <a href="#ga0199871440c4ff89a204cc1d8a09f283">More...</a><br /></td></tr>
 <tr class="separator:ga0199871440c4ff89a204cc1d8a09f283"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
-<tr class="memdesc:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the outcome of SASL negotiation.  <a href="#ga03b6daf742db6a07bd7d03cb197aedb6">More...</a><br /></td></tr>
+<tr class="memitem:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memItemLeft" align="right" valign="top"><a id="ga03b6daf742db6a07bd7d03cb197aedb6"></a>
+<a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
+<tr class="memdesc:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the outcome of SASL negotiation. <br /></td></tr>
 <tr class="separator:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga700e1d505068f895383dd932af55987e"><td class="memItemLeft" align="right" valign="top">const char *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga700e1d505068f895383dd932af55987e">pn_sasl_get_user</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
 <tr class="memdesc:ga700e1d505068f895383dd932af55987e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the authenticated user.  <a href="#ga700e1d505068f895383dd932af55987e">More...</a><br /></td></tr>
@@ -249,7 +250,7 @@ Functions</h2></td></tr>
 
 <p>Do we support extended SASL negotiation. </p>
 <p>Do we support extended SASL negotiation? All implementations of Proton support ANONYMOUS and EXTERNAL on both client and server sides and PLAIN on the client side.</p>
-<p>Extended SASL implememtations use an external library (Cyrus SASL) to support other mechanisms beyond these basic ones.</p>
+<p>Extended SASL implementations use an external library (Cyrus SASL) to support other mechanisms beyond these basic ones.</p>
 <dl class="section return"><dt>Returns</dt><dd>true if we support extended SASL negotiation, false if we only support basic negotiation. </dd></dl>
 
 </div>
@@ -281,27 +282,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Set the outcome of SASL negotiation. </p>
-<p>Used by the server to set the result of the negotiation process.</p>
-
-</div>
-</div>
-<a id="ga03b6daf742db6a07bd7d03cb197aedb6"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ga03b6daf742db6a07bd7d03cb197aedb6">&#9670;&nbsp;</a></span>pn_sasl_outcome()</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname"><a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a> pn_sasl_outcome </td>
-          <td>(</td>
-          <td class="paramtype"><a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *&#160;</td>
-          <td class="paramname"><em>sasl</em></td><td>)</td>
-          <td></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-<p>Retrieve the outcome of SASL negotiation. </p>
+<p>Used by the server to set the result of the negotiation process. </p>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__session.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__session.html b/content/releases/qpid-proton-master/proton/c/api/group__session.html
index 9904d28..5355201 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__session.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__session.html
@@ -115,8 +115,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga0f95b5177494a68991d75444c2f6f812"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a session object.  <a href="#ga0f95b5177494a68991d75444c2f6f812">More...</a><br /></td></tr>
 <tr class="separator:ga0f95b5177494a68991d75444c2f6f812"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
+<tr class="memdesc:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>.  <a href="#ga07da6cda67bdb37511b0aa9c8a04d532">More...</a><br /></td></tr>
 <tr class="separator:ga07da6cda67bdb37511b0aa9c8a04d532"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga31f2e4cc76135f79e96453aa72d441b2"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, void *context)</td></tr>
+<tr class="memdesc:ga31f2e4cc76135f79e96453aa72d441b2"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>.  <a href="#ga31f2e4cc76135f79e96453aa72d441b2">More...</a><br /></td></tr>
 <tr class="separator:ga31f2e4cc76135f79e96453aa72d441b2"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga0128a4413f413569b91e2bc78217728a"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a">pn_session_attachments</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
 <tr class="memdesc:ga0128a4413f413569b91e2bc78217728a"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a session object.  <a href="#ga0128a4413f413569b91e2bc78217728a">More...</a><br /></td></tr>
@@ -125,6 +127,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga7e2a4567e3488a225257e4d883a7e78f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the endpoint state flags for a session.  <a href="#ga7e2a4567e3488a225257e4d883a7e78f">More...</a><br /></td></tr>
 <tr class="separator:ga7e2a4567e3488a225257e4d883a7e78f"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
+<tr class="memdesc:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="#ga1685531ca6fb6fb1058d5455a3c3edde">More...</a><br /></td></tr>
 <tr class="separator:ga1685531ca6fb6fb1058d5455a3c3edde"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gafdb7b3d530adaaf30aecc73ca6319cf3"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3">pn_session_condition</a> (<a class="el" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session)</td></tr>
 <tr class="memdesc:gafdb7b3d530adaaf30aecc73ca6319cf3"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local condition associated with the session endpoint.  <a href="#gafdb7b3d530adaaf30aecc73ca6319cf3">More...</a><br /></td></tr>
@@ -257,8 +260,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>. </p>
 <p>Get the application context that is associated with a session object.</p>
-<p>The application context for a session may be set using <a class="el" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a>.</p>
+<p>The application context for a session may be set using <a class="el" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2" title="Deprecated - Use pn_session_attachments(). ">pn_session_set_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">session</td><td>the session whose context is to be returned. </td></tr>
@@ -294,8 +299,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__session.html#ga0128a4413f413569b91e2bc78217728a" title="Get the attachments that are associated with a session object. ">pn_session_attachments()</a>. </p>
 <p>Set a new application context for a session object.</p>
-<p>The application context for a session object may be retrieved using <a class="el" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a>.</p>
+<p>The application context for a session object may be retrieved using <a class="el" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532" title="Deprecated - Use pn_session_attachments(). ">pn_session_get_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">session</td><td>the session object </td></tr>
@@ -375,6 +382,8 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> </p>
 <p>Get additional error information associated with the session.</p>
 <p>Whenever a session operation fails (i.e. returns an error code), additional error details can be obtained using this function. The error object that is returned may also be used to clear the error condition.</p>
 <p>The pointer returned by this operation is valid until the session object is freed.</p>
@@ -545,7 +554,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Get the incoming capacity of the session measured in bytes. </p>
-<p>The incoming capacity of a session determines how much incoming message data the session will buffer. Note that if this value is less than the negotiated frame size of the transport, it will be rounded up to one full frame.</p>
+<p>The incoming capacity of a session determines how much incoming message data the session can buffer.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">session</td><td>the session object </td></tr>
@@ -583,11 +592,12 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Set the incoming capacity for a session object. </p>
-<p>The incoming capacity of a session determines how much incoming message data the session will buffer. Note that if this value is less than the negotiated frame size of the transport, it will be rounded up to one full frame.</p>
+<p>The incoming capacity of a session determines how much incoming message data the session can buffer, by governing the size of the session incoming-window for transfer frames. This happens in concert with the transport max frame size, and only when both values have been set.</p>
+<p>NOTE: If set, this value must be greater than or equal to the negotiated frame size of the transport. The window is computed as a whole number of frames when dividing remaining capacity at a given time by the connection max frame size. As such, capacity and max frame size should be chosen so as to ensure the frame window isn't unduly small and limiting performance.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">session</td><td>the session object </td></tr>
-    <tr><td class="paramdir">[in]</td><td class="paramname">capacity</td><td>the incoming capacity for the session </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">capacity</td><td>the incoming capacity for the session in bytes </td></tr>
   </table>
   </dd>
 </dl>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__ssl.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__ssl.html b/content/releases/qpid-proton-master/proton/c/api/group__ssl.html
index 4821e01..86b6ee6 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__ssl.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__ssl.html
@@ -169,6 +169,12 @@ Functions</h2></td></tr>
 <tr class="memitem:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">pn_ssl_domain_set_peer_authentication</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const <a class="el" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode, const char *trusted_CAs)</td></tr>
 <tr class="memdesc:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the level of verification used on the peer certificate.  <a href="#ga39b67bd22fb8f0a47bcdbdfd40f80b11">More...</a><br /></td></tr>
 <tr class="separator:ga39b67bd22fb8f0a47bcdbdfd40f80b11"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga333fcb941ed20421373f37b23d84fc98"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">pn_ssl_domain_set_protocols</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const char *protocols)</td></tr>
+<tr class="memdesc:ga333fcb941ed20421373f37b23d84fc98"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the list of permitted TLS protocols.  <a href="#ga333fcb941ed20421373f37b23d84fc98">More...</a><br /></td></tr>
+<tr class="separator:ga333fcb941ed20421373f37b23d84fc98"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">pn_ssl_domain_set_ciphers</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, const char *ciphers)</td></tr>
+<tr class="memdesc:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="mdescLeft">&#160;</td><td class="mdescRight">Configure the list of permitted ciphers.  <a href="#gac3da0f48aeeb11d8149a559a2a064ddc">More...</a><br /></td></tr>
+<tr class="separator:gac3da0f48aeeb11d8149a559a2a064ddc"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2ac989a62dcd138be770fae0bbb85e74"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">pn_ssl_domain_allow_unsecured_client</a> (<a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain)</td></tr>
 <tr class="memdesc:ga2ac989a62dcd138be770fae0bbb85e74"><td class="mdescLeft">&#160;</td><td class="mdescRight">Permit a server to accept connection requests from non-SSL clients.  <a href="#ga2ac989a62dcd138be770fae0bbb85e74">More...</a><br /></td></tr>
 <tr class="separator:ga2ac989a62dcd138be770fae0bbb85e74"><td class="memSeparator" colspan="2">&#160;</td></tr>
@@ -552,6 +558,84 @@ This setting effects only those pn_ssl_t objects created after this call returns
 
 </div>
 </div>
+<a id="ga333fcb941ed20421373f37b23d84fc98"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ga333fcb941ed20421373f37b23d84fc98">&#9670;&nbsp;</a></span>pn_ssl_domain_set_protocols()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">int pn_ssl_domain_set_protocols </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *&#160;</td>
+          <td class="paramname"><em>domain</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">const char *&#160;</td>
+          <td class="paramname"><em>protocols</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Configure the list of permitted TLS protocols. </p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramdir">[in]</td><td class="paramname">domain</td><td>the ssl domain to configure. </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">protocols</td><td>string representing the protocol list. This list is a space separated string of the allowed TLS protocols, The current possibilities are TLSv1 TLSv1.1 TLSv1.2. None of the earlier SSL protocols are allowed for security reason.</td></tr>
+  </table>
+  </dd>
+</dl>
+<dl class="section note"><dt>Note</dt><dd>If this API not called then all the TLS protocols are allowed. The API only acts to restrict the allowed protocols to the specified set. </dd></dl>
+<dl class="section return"><dt>Returns</dt><dd>0 on success </dd></dl>
+
+</div>
+</div>
+<a id="gac3da0f48aeeb11d8149a559a2a064ddc"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#gac3da0f48aeeb11d8149a559a2a064ddc">&#9670;&nbsp;</a></span>pn_ssl_domain_set_ciphers()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">int pn_ssl_domain_set_ciphers </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *&#160;</td>
+          <td class="paramname"><em>domain</em>, </td>
+        </tr>
+        <tr>
+          <td class="paramkey"></td>
+          <td></td>
+          <td class="paramtype">const char *&#160;</td>
+          <td class="paramname"><em>ciphers</em>&#160;</td>
+        </tr>
+        <tr>
+          <td></td>
+          <td>)</td>
+          <td></td><td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Configure the list of permitted ciphers. </p>
+<dl class="section note"><dt>Note</dt><dd>The syntax of the permitted list is undefined and will depend on the underlying SSL implementation.</dd></dl>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramdir">[in]</td><td class="paramname">domain</td><td>the ssl domain to configure. </td></tr>
+    <tr><td class="paramdir">[in]</td><td class="paramname">ciphers</td><td>string representing the cipher list </td></tr>
+  </table>
+  </dd>
+</dl>
+<dl class="section return"><dt>Returns</dt><dd>0 on success </dd></dl>
+
+</div>
+</div>
 <a id="ga2ac989a62dcd138be770fae0bbb85e74"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#ga2ac989a62dcd138be770fae0bbb85e74">&#9670;&nbsp;</a></span>pn_ssl_domain_allow_unsecured_client()</h2>
 

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__ssl.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__ssl.js b/content/releases/qpid-proton-master/proton/c/api/group__ssl.js
index 7d8968b..dacde1a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__ssl.js
+++ b/content/releases/qpid-proton-master/proton/c/api/group__ssl.js
@@ -25,6 +25,8 @@ var group__ssl =
     [ "pn_ssl_domain_set_credentials", "group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa", null ],
     [ "pn_ssl_domain_set_trusted_ca_db", "group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d", null ],
     [ "pn_ssl_domain_set_peer_authentication", "group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11", null ],
+    [ "pn_ssl_domain_set_protocols", "group__ssl.html#ga333fcb941ed20421373f37b23d84fc98", null ],
+    [ "pn_ssl_domain_set_ciphers", "group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc", null ],
     [ "pn_ssl_domain_allow_unsecured_client", "group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74", null ],
     [ "pn_ssl", "group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c", null ],
     [ "pn_ssl_init", "group__ssl.html#ga45f319dd31ad456b8a85927888f94acf", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__terminus.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__terminus.html b/content/releases/qpid-proton-master/proton/c/api/group__terminus.html
index 67016e6..49d220f 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__terminus.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__terminus.html
@@ -281,7 +281,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Expiry policy of an AMQP terminus. </p>
-<p>An orphaned terminus can only exist for the timeout configured by <a class="el" href="group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d" title="Set the timeout of a terminus object. ">pn_terminus_set_timeout</a>. The expiry policy determins when a terminus is considered orphaned, i.e. when the expiry timer starts counting down. </p>
+<p>An orphaned terminus can only exist for the timeout configured by <a class="el" href="group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d" title="Set the timeout of a terminus object. ">pn_terminus_set_timeout</a>. The expiry policy determines when a terminus is considered orphaned, i.e. when the expiry timer starts counting down. </p>
 <table class="fieldtable">
 <tr><th colspan="2">Enumerator</th></tr><tr><td class="fieldname"><a id="ggab4089b27ee99a348deab776f3d4931f0ad559c0f96078b8b7d8b84b77354b2391"></a>PN_EXPIRE_WITH_LINK&#160;</td><td class="fielddoc"><p>the terminus is orphaned when the parent link is closed </p>
 </td></tr>


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


[31/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/object_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/object_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/object_8h_source.html
index 55105c8..39c54d7 100755
--- a/content/releases/qpid-proton-master/proton/c/api/object_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/object_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/object.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('object_8h_source.html','');});
 <div class="title">object.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_OBJECT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_OBJECT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="
 l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><spa
 n class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   
 20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/cid.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor
 ">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif<
 /span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">void</span>* pn_handle_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> intptr_t pn_shandle_t;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_class_t pn_class_t;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_string_t pn_string_t;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struc
 t </span>pn_list_t pn_list_t;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_map_t pn_map_t;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_hash_t pn_hash_t;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">void</span> *(*pn_iterator_next_t)(<span class="keywordtype">void</span> *state);</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_iterator_t pn_iterator_t;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_record_t pn_record_t;</div><div class="line
 "><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="keyword">struct </span>pn_class_t {</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;  <span class="keyword">const</span> <span class="keywordtype">char</span> *name;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;  <span class="keyword">const</span> pn_cid_t cid;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  <span class="keywordtype">void</span> *(*newinst)(<span class="keyword">const</span> pn_class_t *, size_t);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;  void (*initialize)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  void (*incref)(<span class="keywordtype">void</span> *);</div><div class="line"
 ><a name="l00058"></a><span class="lineno">   58</span>&#160;  void (*decref)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;  int (*refcount)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;  void (*finalize)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;  void (*free)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;  <span class="keyword">const</span> pn_class_t *(*reify)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;  uintptr_t (*hashcode)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;  intptr_t (*compare)(<span class="
 keywordtype">void</span> *, <span class="keywordtype">void</span> *);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;  int (*inspect)(<span class="keywordtype">void</span> *, pn_string_t *);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;};</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="comment">// Hack alert: Declare these as arrays so we can treat the name</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="comment">// of the single object as the address</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PN_EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_OBJECT[];</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;PN
 _EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_VOID[];</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PN_EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_WEAKREF[];</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#define PN_CLASSDEF(PREFIX)                                               \</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">static void PREFIX ## _initialize_cast(void *object) {                    \</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">  PREFIX ## _initialize((PREFIX ## _t *) object);                         \</span></div><div class="line"><a name="l00077"></a>
 <span class="lineno">   77</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">static void PREFIX ## _finalize_cast(void *object) {                      \</span></div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">  PREFIX ## _finalize((PREFIX ## _t *) object);                           \</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span
 >&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor">static uintptr_t PREFIX ## _hashcode_cast(void *object) {                 \</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="preprocessor">  uintptr_t (*fp)(PREFIX ## _t *) = PREFIX ## _hashcode;                  \</span></div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) object);                                   \</span></div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;<span class="preprocessor
 ">  } else {                                                                \</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="preprocessor">    return (uintptr_t) object;                                            \</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;<span class="preprocessor">  }                                                                       \</span></div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="preprocessor">static intptr_t PREFIX ## _com
 pare_cast(void *a, void *b) {               \</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="preprocessor">  intptr_t (*fp)(PREFIX ## _t *, PREFIX ## _t *) = PREFIX ## _compare;    \</span></div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) a, (PREFIX ## _t *) b);                    \</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="preprocessor">  } else {                                                                \</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="preprocessor">    return (intptr_t) a - (intptr_t) b;                       
             \</span></div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">  }                                                                       \</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;<span class="preprocessor">static int PREFIX ## _inspect_cast(void *object, pn_string_t *str) {      \</span></div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">  int (*fp)(PREFIX ## _t *, pn_string_t *) = PREFIX ## _inspect;          \</span></div><div c
 lass="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) object, str);                              \</span></div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="preprocessor">  } else {                                                                \</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor">    return pn_string_addf(str, &quot;%s&lt;%p&gt;&quot;, #PREFIX, object);                \</span></div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;<span class="preprocessor">  }                                                                       \</span></div><div class="line"><a n
 ame="l00108"></a><span class="lineno">  108</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">const pn_class_t *PREFIX ## __class(void) {                               \</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">  static const pn_class_t clazz = {                                       \</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor">    #PREFIX,                                                              \</span></div><div class="line"><a name="l00113"></a><span class="li
 neno">  113</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                                                       \</span></div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;<span class="preprocessor">    pn_object_new,                                                        \</span></div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">    PREFIX ## _initialize_cast,                                           \</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">    pn_object_incref,                                                     \</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">    pn_object_decref,                                                     \</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;<span cl
 ass="preprocessor">    pn_object_refcount,                                                   \</span></div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">    PREFIX ## _finalize_cast,                                             \</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor">    pn_object_free,                                                       \</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;<span class="preprocessor">    pn_object_reify,                                                      \</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode_cast,                                             \</span></div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<span class="preprocessor">    PREFIX ##
  _compare_cast,                                              \</span></div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="preprocessor">    PREFIX ## _inspect_cast                                               \</span></div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor">  };                                                                      \</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">  return &amp;clazz;                                                          \</span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">                                         
                                  \</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">PREFIX ## _t *PREFIX ## _new(void) {                                      \</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;<span class="preprocessor">  return (PREFIX ## _t *) pn_class_new(PREFIX ## __class(),               \</span></div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">                                       sizeof(PREFIX ## _t));             \</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;<span class="preprocessor">#define PN_CLASS(PREFIX) {                      \</span></div><
 div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;<span class="preprocessor">    #PREFIX,                                    \</span></div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                             \</span></div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;<span class="preprocessor">    pn_object_new,                              \</span></div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;<span class="preprocessor">    PREFIX ## _initialize,                      \</span></div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="preprocessor">    pn_object_incref,                           \</span></div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;<span class="preprocessor">    pn_object_decref,                           \</span></
 div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="preprocessor">    pn_object_refcount,                         \</span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;<span class="preprocessor">    PREFIX ## _finalize,                        \</span></div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;<span class="preprocessor">    pn_object_free,                             \</span></div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;<span class="preprocessor">    pn_object_reify,                            \</span></div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode,                        \</span></div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;<span class="preprocessor">    PREFIX ## _compare,                         \</sp
 an></div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;<span class="preprocessor">    PREFIX ## _inspect                          \</span></div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;<span class="preprocessor">#define PN_METACLASS(PREFIX) {                  \</span></div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;<span class="preprocessor">    #PREFIX,                                    \</span></div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                             \</span></div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;<span class="preprocessor">    PREFIX #
 # _new,                             \</span></div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;<span class="preprocessor">    PREFIX ## _initialize,                      \</span></div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;<span class="preprocessor">    PREFIX ## _incref,                          \</span></div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;<span class="preprocessor">    PREFIX ## _decref,                          \</span></div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;<span class="preprocessor">    PREFIX ## _refcount,                        \</span></div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;<span class="preprocessor">    PREFIX ## _finalize,                        \</span></div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;<span class="preprocessor">    PRE
 FIX ## _free,                            \</span></div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;<span class="preprocessor">    PREFIX ## _reify,                           \</span></div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode,                        \</span></div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;<span class="preprocessor">    PREFIX ## _compare,                         \</span></div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;<span class="preprocessor">    PREFIX ## _inspect                          \</span></div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span
 >&#160;<span class="comment">/* Class to identify a plain C struct in a pn_event_t. No refcounting or memory management. */</span></div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;<span class="preprocessor">#define PN_STRUCT_CLASSDEF(PREFIX, CID)                                 \</span></div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;<span class="preprocessor">  const pn_class_t *PREFIX ## __class(void);                            \</span></div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;<span class="preprocessor">  static const pn_class_t *PREFIX ## _reify(void *p) { return PREFIX ## __class(); } \</span></div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;<span class="preprocessor">  const pn_class_t *PREFIX  ##  __class(void) {                         \</span></div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;<span 
 class="preprocessor">  static const pn_class_t clazz = {                                     \</span></div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;<span class="preprocessor">    #PREFIX,                                                            \</span></div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;<span class="preprocessor">    CID,                                                                \</span></div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/*_new*/</span><span class="preprocessor">                                                      \</span></div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/*_initialize*/</span><span class="preprocessor">                                               \</span></div>
 <div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;<span class="preprocessor">    pn_void_incref,                                                     \</span></div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;<span class="preprocessor">    pn_void_decref,                                                     \</span></div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;<span class="preprocessor">    pn_void_refcount,                                                   \</span></div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/* _finalize */</span><span class="preprocessor">                                               \</span></div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/* _free */</span><span cl
 ass="preprocessor">                                                   \</span></div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;<span class="preprocessor">    PREFIX ## _reify,                                                   \</span></div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;<span class="preprocessor">    pn_void_hashcode,                                                   \</span></div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;<span class="preprocessor">    pn_void_compare,                                                    \</span></div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;<span class="preprocessor">    pn_void_inspect                                                     \</span></div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;<span class="preprocessor">    };                                      
                             \</span></div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;<span class="preprocessor">  return &amp;clazz;                                                        \</span></div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;<span class="preprocessor">  }</span></div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;PN_EXTERN pn_cid_t pn_class_id(<span class="keyword">const</span> pn_class_t *clazz);</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_class_name(<span class="keyword">const</span> pn_class_t *clazz);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_class_new(<span clas
 s="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;<span class="comment">/* pn_incref, pn_decref and pn_refcount are for internal use by the proton</span></div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;<span class="comment">   library, the should not be called by application code. Application code</span></div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;<span class="comment">   should use the appropriate pn_*_free function (pn_link_free, pn_session_free</span></div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;<span class="comment">   etc.) when it is finished with a proton value. Proton values should only be</span></div><div class="line"><a name="l00197"></a><span class="lineno">
   197</span>&#160;<span class="comment">   used when handling a pn_event_t that refers to them.</span></div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;<span class="comment">*/</span></div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_class_incref(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_class_refcount(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_class_decref(<span class="keyword">const</span> pn_class_t *clazz, <span class="
 keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_class_free(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;PN_EXTERN <span class="keyword">const</span> pn_class_t *pn_class_reify(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;PN_EXTERN uintptr_t pn_class_hashcode(<span class="keyword">const</span> pn_class_t *clazz, <span class="key
 wordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;PN_EXTERN intptr_t pn_class_compare(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *a, <span class="keywordtype">void</span> *b);</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> pn_class_equals(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *a, <span class="keywordtype">void</span> *b);</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_class_inspect(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span class="keywordtype">object</span>, pn_string_t *dst);</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;</div
 ><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_void_new(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_void_incref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_void_decref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_void_refcount(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00215"></a><span class="lineno">  215</sp
 an>&#160;PN_EXTERN uintptr_t pn_void_hashcode(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;PN_EXTERN intptr_t pn_void_compare(<span class="keywordtype">void</span> *a, <span class="keywordtype">void</span> *b);</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_void_inspect(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>, pn_string_t *dst);</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;</div><div class="line"><a name="l00219"></a><span class="lineno">  219</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_object_new(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00220"></a><span class="lineno">  220</span>&#160;PN_EXTER
 N <span class="keyword">const</span> pn_class_t *pn_object_reify(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_object_incref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_object_refcount(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00223"></a><span class="lineno">  223</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_object_decref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00224"></a><span class="lineno">  224</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_object_free(<span class="keyw
 ordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_incref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_decref(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_refcount(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_free(<span class="keywordtype">void</span> *<spa
 n class="keywordtype">object</span>);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;PN_EXTERN <span class="keyword">const</span> pn_class_t *pn_class(<span class="keywordtype">void</span>* <span class="keywordtype">object</span>);</div><div class="line"><a name="l00231"></a><span class="lineno">  231</span>&#160;PN_EXTERN uintptr_t pn_hashcode(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00232"></a><span class="lineno">  232</span>&#160;PN_EXTERN intptr_t pn_compare(<span class="keywordtype">void</span> *a, <span class="keywordtype">void</span> *b);</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> pn_equals(<span class="keywordtype">void</span> *a, <span class="keywordtype">void</span> *b);</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PN_EXTERN <span class="key
 wordtype">int</span> pn_inspect(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>, pn_string_t *dst);</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;<span class="preprocessor">#define PN_REFCOUNT (0x1)</span></div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;PN_EXTERN pn_list_t *pn_list(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">size_t</span> capacity);</div><div class="line"><a name="l00239"></a><span class="lineno">  239</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> pn_list_size(pn_list_t *list);</div><div class="line"><a name="l00240"></a><span class="lineno">  240</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_list_get(pn_list_t *list, <span class="
 keywordtype">int</span> index);</div><div class="line"><a name="l00241"></a><span class="lineno">  241</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_list_set(pn_list_t *list, <span class="keywordtype">int</span> index, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_list_add(pn_list_t *list, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_list_pop(pn_list_t *list);</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;PN_EXTERN ssize_t pn_list_index(pn_list_t *list, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> pn_list_remove(pn_list_t *list, <spa
 n class="keywordtype">void</span> *value);</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_list_del(pn_list_t *list, <span class="keywordtype">int</span> index, <span class="keywordtype">int</span> n);</div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_list_clear(pn_list_t *list);</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_list_iterator(pn_list_t *list, pn_iterator_t *iter);</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_list_minpush(pn_list_t *list, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_list_minpop(p
 n_list_t *list);</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;<span class="preprocessor">#define PN_REFCOUNT_KEY (0x2)</span></div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;<span class="preprocessor">#define PN_REFCOUNT_VALUE (0x4)</span></div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;PN_EXTERN pn_map_t *pn_map(<span class="keyword">const</span> pn_class_t *key, <span class="keyword">const</span> pn_class_t *value,</div><div class="line"><a name="l00256"></a><span class="lineno">  256</span>&#160;                           <span class="keywordtype">size_t</span> capacity, <span class="keywordtype">float</span> load_factor);</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;PN_E
 XTERN <span class="keywordtype">size_t</span> pn_map_size(pn_map_t *map);</div><div class="line"><a name="l00258"></a><span class="lineno">  258</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_map_put(pn_map_t *map, <span class="keywordtype">void</span> *key, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00259"></a><span class="lineno">  259</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_map_get(pn_map_t *map, <span class="keywordtype">void</span> *key);</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_map_del(pn_map_t *map, <span class="keywordtype">void</span> *key);</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PN_EXTERN pn_handle_t pn_map_head(pn_map_t *map);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;PN_EXTERN pn_handle_t pn_map_next(pn_map_t *map, pn_han
 dle_t entry);</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_map_key(pn_map_t *map, pn_handle_t entry);</div><div class="line"><a name="l00264"></a><span class="lineno">  264</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_map_value(pn_map_t *map, pn_handle_t entry);</div><div class="line"><a name="l00265"></a><span class="lineno">  265</span>&#160;</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;PN_EXTERN pn_hash_t *pn_hash(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">size_t</span> capacity, <span class="keywordtype">float</span> load_factor);</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> pn_hash_size(pn_hash_t *hash);</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;PN_EXTERN <span class="ke
 ywordtype">int</span> pn_hash_put(pn_hash_t *hash, uintptr_t key, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_hash_get(pn_hash_t *hash, uintptr_t key);</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_hash_del(pn_hash_t *hash, uintptr_t key);</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN pn_handle_t pn_hash_head(pn_hash_t *hash);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;PN_EXTERN pn_handle_t pn_hash_next(pn_hash_t *hash, pn_handle_t entry);</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;PN_EXTERN uintptr_t pn_hash_key(pn_hash_t *hash, pn_handle_t entry);</div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;PN_EX
 TERN <span class="keywordtype">void</span> *pn_hash_value(pn_hash_t *hash, pn_handle_t entry);</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;</div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;PN_EXTERN pn_string_t *pn_string(<span class="keyword">const</span> <span class="keywordtype">char</span> *bytes);</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;PN_EXTERN pn_string_t *pn_stringn(<span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_string_get(pn_string_t *<span class="keywordtype">string</span>);</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> pn_string
 _size(pn_string_t *<span class="keywordtype">string</span>);</div><div class="line"><a name="l00280"></a><span class="lineno">  280</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_set(pn_string_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes);</div><div class="line"><a name="l00281"></a><span class="lineno">  281</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_setn(pn_string_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00282"></a><span class="lineno">  282</span>&#160;PN_EXTERN ssize_t pn_string_put(pn_string_t *<span class="keywordtype">string</span>, <span class="keywordtype">char</span> *dst);</div><div class="line"><a name="l00283"></a><span class="lineno">  283</span>&#160;PN_EXTERN <span class="keywordtype"
 >void</span> pn_string_clear(pn_string_t *<span class="keywordtype">string</span>);</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_format(pn_string_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, ...)</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;<span class="preprocessor">#ifdef __GNUC__</span></div><div class="line"><a name="l00286"></a><span class="lineno">  286</span>&#160;  __attribute__ ((format (printf, 2, 3)))</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;    ;</div><div class="line"><a name="l00289"></a><span class="lineno">  289</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_vformat(pn_str
 ing_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, va_list ap);</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_addf(pn_string_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, ...)</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;<span class="preprocessor">#ifdef __GNUC__</span></div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;  __attribute__ ((format (printf, 2, 3)))</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;    ;</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;PN_EXTERN <spa
 n class="keywordtype">int</span> pn_string_vaddf(pn_string_t *<span class="keywordtype">string</span>, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, va_list ap);</div><div class="line"><a name="l00296"></a><span class="lineno">  296</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_grow(pn_string_t *<span class="keywordtype">string</span>, <span class="keywordtype">size_t</span> capacity);</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;PN_EXTERN <span class="keywordtype">char</span> *pn_string_buffer(pn_string_t *<span class="keywordtype">string</span>);</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> pn_string_capacity(pn_string_t *<span class="keywordtype">string</span>);</div><div class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_strin
 g_resize(pn_string_t *<span class="keywordtype">string</span>, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00300"></a><span class="lineno">  300</span>&#160;PN_EXTERN <span class="keywordtype">int</span> pn_string_copy(pn_string_t *<span class="keywordtype">string</span>, pn_string_t *src);</div><div class="line"><a name="l00301"></a><span class="lineno">  301</span>&#160;</div><div class="line"><a name="l00302"></a><span class="lineno">  302</span>&#160;PN_EXTERN pn_iterator_t *pn_iterator(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00303"></a><span class="lineno">  303</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_iterator_start(pn_iterator_t *iterator,</div><div class="line"><a name="l00304"></a><span class="lineno">  304</span>&#160;                                  pn_iterator_next_t next, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00305"></a><span class="line
 no">  305</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_iterator_next(pn_iterator_t *iterator);</div><div class="line"><a name="l00306"></a><span class="lineno">  306</span>&#160;</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;<span class="preprocessor">#define PN_LEGCTX ((pn_handle_t) 0)</span></div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;</div><div class="line"><a name="l00315"></a><span class="lineno">  315</span>&#160;</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;</div><div class="line"><a name="l00326"></a><span class="lineno">  326</span>&#160;<span class="preprocessor">#define PN_HANDLE(name) \</span></div><div class="line"><a name="l00327"></a><span class="lineno">  327</span>&#160;<span class="preprocessor">  static const char _PN_HANDLE_ ## name = 0; \</span></div><div class="line"><a name="l00328"></a><span class="lineno">  328</span>&#160;<spa
 n class="preprocessor">  static const pn_handle_t name = ((pn_handle_t) &amp;_PN_HANDLE_ ## name);</span></div><div class="line"><a name="l00329"></a><span class="lineno">  329</span>&#160;</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;PN_EXTERN pn_record_t *pn_record(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_record_def(pn_record_t *record, pn_handle_t key, <span class="keyword">const</span> pn_class_t *clazz);</div><div class="line"><a name="l00332"></a><span class="lineno">  332</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> pn_record_has(pn_record_t *record, pn_handle_t key);</div><div class="line"><a name="l00333"></a><span class="lineno">  333</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pn_record_get(pn_record_t *record, pn_handle_t key);</div><div class="line"><a name="l00334"></a>
 <span class="lineno">  334</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_record_set(pn_record_t *record, pn_handle_t key, <span class="keywordtype">void</span> *value);</div><div class="line"><a name="l00335"></a><span class="lineno">  335</span>&#160;PN_EXTERN <span class="keywordtype">void</span> pn_record_clear(pn_record_t *record);</div><div class="line"><a name="l00336"></a><span class="lineno">  336</span>&#160;</div><div class="line"><a name="l00341"></a><span class="lineno">  341</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00342"></a><span class="lineno">  342</span>&#160;}</div><div class="line"><a name="l00343"></a><span class="lineno">  343</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00344"></a><span class="lineno">  344</span>&#160;</div><div class="line"><a name="l00345"></a><span class="lineno">  345</span>&#160;<span class="preprocessor">#endif </span><span
  class="comment">/* object.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_OBJECT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_OBJECT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="
 l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><spa
 n class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   
 20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/cid.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor
 ">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif<
 /span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">typedef</span> <span class="keyword">const</span> <span class="keywordtype">void</span>* pn_handle_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> intptr_t pn_shandle_t;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_class_t pn_class_t;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_string_t pn_string_t;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="keyword">typedef
 </span> <span class="keyword">struct </span>pn_list_t pn_list_t;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_map_t pn_map_t;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_hash_t pn_hash_t;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">void</span> *(*pn_iterator_next_t)(<span class="keywordtype">void</span> *state);</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_iterator_t pn_iterator_t;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_record_t
  pn_record_t;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="keyword">struct </span>pn_class_t {</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;  <span class="keyword">const</span> <span class="keywordtype">char</span> *name;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;  <span class="keyword">const</span> pn_cid_t cid;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  <span class="keywordtype">void</span> *(*newinst)(<span class="keyword">const</span> pn_class_t *, size_t);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;  void (*initialize)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  void (*incref)(<span class="keywordtype">voi
 d</span> *);</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;  void (*decref)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;  int (*refcount)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;  void (*finalize)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;  void (*free)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;  <span class="keyword">const</span> pn_class_t *(*reify)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;  uintptr_t (*hashcode)(<span class="keywordtype">void</span> *);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;
   intptr_t (*compare)(<span class="keywordtype">void</span> *, <span class="keywordtype">void</span> *);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;  int (*inspect)(<span class="keywordtype">void</span> *, pn_string_t *);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;};</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="comment">/* Hack alert: Declare these as arrays so we can treat the name of the single</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="comment">   object as the address */</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PN_EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_OBJECT[];</div><div class="line"><a name="l00071"></a><sp
 an class="lineno">   71</span>&#160;PN_EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_VOID[];</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PN_EXTERN <span class="keyword">extern</span> <span class="keyword">const</span> pn_class_t PN_WEAKREF[];</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#define PN_CLASSDEF(PREFIX)                                               \</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">static void PREFIX ## _initialize_cast(void *object) {                    \</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">  PREFIX ## _initialize((PREFIX ## _t *) object);                         \</span></div><
 div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">static void PREFIX ## _finalize_cast(void *object) {                      \</span></div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">  PREFIX ## _finalize((PREFIX ## _t *) object);                           \</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00082
 "></a><span class="lineno">   82</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor">static uintptr_t PREFIX ## _hashcode_cast(void *object) {                 \</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="preprocessor">  uintptr_t (*fp)(PREFIX ## _t *) = PREFIX ## _hashcode;                  \</span></div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) object);                                   \</span></div><div class="line"><a name="l00087"></a><span class="lineno">   87
 </span>&#160;<span class="preprocessor">  } else {                                                                \</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="preprocessor">    return (uintptr_t) object;                                            \</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;<span class="preprocessor">  }                                                                       \</span></div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="prepro
 cessor">static intptr_t PREFIX ## _compare_cast(void *a, void *b) {               \</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="preprocessor">  intptr_t (*fp)(PREFIX ## _t *, PREFIX ## _t *) = PREFIX ## _compare;    \</span></div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) a, (PREFIX ## _t *) b);                    \</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="preprocessor">  } else {                                                                \</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="preprocessor">    return (intptr_t) a 
 - (intptr_t) b;                                   \</span></div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">  }                                                                       \</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;<span class="preprocessor">static int PREFIX ## _inspect_cast(void *object, pn_string_t *str) {      \</span></div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">  int (*fp)(PREFIX ## _t *, pn_string_t *) = PREFIX ## _
 inspect;          \</span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;<span class="preprocessor">  if (fp) {                                                               \</span></div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;<span class="preprocessor">    return fp((PREFIX ## _t *) object, str);                              \</span></div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="preprocessor">  } else {                                                                \</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor">    return pn_string_addf(str, &quot;%s&lt;%p&gt;&quot;, #PREFIX, object);                \</span></div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;<span class="preprocessor">  }                                                                     
   \</span></div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="preprocessor">                                                                          \</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">const pn_class_t *PREFIX ## __class(void) {                               \</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">  static const pn_class_t clazz = {                                       \</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor">    #PREFIX,                                                              \</span></div><div class="line
 "><a name="l00113"></a><span class="lineno">  113</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                                                       \</span></div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;<span class="preprocessor">    pn_object_new,                                                        \</span></div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">    PREFIX ## _initialize_cast,                                           \</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">    pn_object_incref,                                                     \</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">    pn_object_decref,                                                     \</span></div><div class="line"><a name="l00118"></a><span cla
 ss="lineno">  118</span>&#160;<span class="preprocessor">    pn_object_refcount,                                                   \</span></div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">    PREFIX ## _finalize_cast,                                             \</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor">    pn_object_free,                                                       \</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;<span class="preprocessor">    pn_object_reify,                                                      \</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode_cast,                                             \</span></div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<s
 pan class="preprocessor">    PREFIX ## _compare_cast,                                              \</span></div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="preprocessor">    PREFIX ## _inspect_cast                                               \</span></div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor">  };                                                                      \</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">  return &amp;clazz;                                                          \</span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;<span class="preprocessor">}                                                                         \</span></div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">   
                                                                        \</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">PREFIX ## _t *PREFIX ## _new(void) {                                      \</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;<span class="preprocessor">  return (PREFIX ## _t *) pn_class_new(PREFIX ## __class(),               \</span></div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">                                       sizeof(PREFIX ## _t));             \</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;<span class="preprocessor">#define PN_CLASS(PREFIX) 
 {                      \</span></div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;<span class="preprocessor">    #PREFIX,                                    \</span></div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                             \</span></div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;<span class="preprocessor">    pn_object_new,                              \</span></div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;<span class="preprocessor">    PREFIX ## _initialize,                      \</span></div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="preprocessor">    pn_object_incref,                           \</span></div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;<span class="preprocessor">    pn_object_decref
 ,                           \</span></div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="preprocessor">    pn_object_refcount,                         \</span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;<span class="preprocessor">    PREFIX ## _finalize,                        \</span></div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;<span class="preprocessor">    pn_object_free,                             \</span></div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;<span class="preprocessor">    pn_object_reify,                            \</span></div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode,                        \</span></div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;<span class="preprocessor">    PREFIX ## _
 compare,                         \</span></div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;<span class="preprocessor">    PREFIX ## _inspect                          \</span></div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;<span class="preprocessor">#define PN_METACLASS(PREFIX) {                  \</span></div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;<span class="preprocessor">    #PREFIX,                                    \</span></div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;<span class="preprocessor">    CID_ ## PREFIX,                             \</span></div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;<
 span class="preprocessor">    PREFIX ## _new,                             \</span></div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;<span class="preprocessor">    PREFIX ## _initialize,                      \</span></div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;<span class="preprocessor">    PREFIX ## _incref,                          \</span></div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;<span class="preprocessor">    PREFIX ## _decref,                          \</span></div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;<span class="preprocessor">    PREFIX ## _refcount,                        \</span></div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;<span class="preprocessor">    PREFIX ## _finalize,                        \</span></div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#
 160;<span class="preprocessor">    PREFIX ## _free,                            \</span></div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;<span class="preprocessor">    PREFIX ## _reify,                           \</span></div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;<span class="preprocessor">    PREFIX ## _hashcode,                        \</span></div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;<span class="preprocessor">    PREFIX ## _compare,                         \</span></div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;<span class="preprocessor">    PREFIX ## _inspect                          \</span></div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;<span class="preprocessor">}</span></div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00166
 "></a><span class="lineno">  166</span>&#160;<span class="comment">/* Class to identify a plain C struct in a pn_event_t. No refcounting or memory management. */</span></div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;<span class="preprocessor">#define PN_STRUCT_CLASSDEF(PREFIX, CID)                                 \</span></div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;<span class="preprocessor">  const pn_class_t *PREFIX ## __class(void);                            \</span></div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;<span class="preprocessor">  static const pn_class_t *PREFIX ## _reify(void *p) { return PREFIX ## __class(); } \</span></div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;<span class="preprocessor">  const pn_class_t *PREFIX  ##  __class(void) {                         \</span></div><div class="line"><a name="l00171"></a><span c
 lass="lineno">  171</span>&#160;<span class="preprocessor">  static const pn_class_t clazz = {                                     \</span></div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;<span class="preprocessor">    #PREFIX,                                                            \</span></div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;<span class="preprocessor">    CID,                                                                \</span></div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/*_new*/</span><span class="preprocessor">                                                      \</span></div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/*_initialize*/</span><span class="preprocessor">                       
                         \</span></div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;<span class="preprocessor">    pn_void_incref,                                                     \</span></div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;<span class="preprocessor">    pn_void_decref,                                                     \</span></div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;<span class="preprocessor">    pn_void_refcount,                                                   \</span></div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;<span class="preprocessor">    NULL, </span><span class="comment">/* _finalize */</span><span class="preprocessor">                                               \</span></div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;<span class="preprocessor">    NULL, </span><span clas
 s="comment">/* _free */</span><span class="preprocessor">                                                   \</span></div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;<span class="preprocessor">    PREFIX ## _reify,                                                   \</span></div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;<span class="preprocessor">    pn_void_hashcode,                                                   \</span></div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;<span class="preprocessor">    pn_void_compare,                                                    \</span></div><div class="line"

<TRUNCATED>

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


[14/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target-members.html
index 20af243..7de49aa 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target-members.html
@@ -97,22 +97,23 @@ $(document).ready(function(){initNavTree('classproton_1_1target.html','');});
 <p>This is the complete list of members for <a class="el" href="classproton_1_1target.html">target</a>, including all inherited members.</p>
 <table class="directory">
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target.html#a4744eb217c976c199b678bb5a0d55acf">address</a>() const</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">proton::terminus::durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">proton::terminus::expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target.html#a1839bce0672e60129fb6c69534a027e6">target</a>()</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">proton::terminus::durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1target.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">proton::terminus::expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target.html#a1839bce0672e60129fb6c69534a027e6">target</a>()</td><td class="entry"><a class="el" href="classproton_1_1target.html">target</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.html
index 4f9f568..f73a187 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.html
@@ -149,6 +149,10 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <tr class="memitem:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1value.html">value</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a> () const</td></tr>
 <tr class="memdesc:ab503c82e36aa618e6c6fb34feaad57b8"><td class="mdescLeft">&#160;</td><td class="mdescRight">Obtain a reference to the AMQP dynamic node properties for the terminus.  <a href="#ab503c82e36aa618e6c6fb34feaad57b8">More...</a><br /></td></tr>
 <tr class="separator:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memItemLeft" align="right" valign="top"><a id="a1c6bf68ea1dcbd3b2a0897adb628c1ee"></a>
+std::vector&lt; <a class="el" href="classproton_1_1symbol.html">symbol</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a> () const</td></tr>
+<tr class="memdesc:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="mdescLeft">&#160;</td><td class="mdescRight">Extension capabilities that are supported/requested. <br /></td></tr>
+<tr class="separator:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A destination for messages. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.js
index c1d8a6e..33d784e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target.js
@@ -8,5 +8,6 @@ var classproton_1_1target =
     [ "expiry_policy", "classproton_1_1target.html#afc97dbb9b04812da5be8a41eb9434904", null ],
     [ "timeout", "classproton_1_1target.html#a16d54f985193a3ce6ac69ffe10e8dfb6", null ],
     [ "dynamic", "classproton_1_1target.html#adcc4ef24adb8478230018c519aa636ec", null ],
-    [ "node_properties", "classproton_1_1target.html#ab503c82e36aa618e6c6fb34feaad57b8", null ]
+    [ "node_properties", "classproton_1_1target.html#ab503c82e36aa618e6c6fb34feaad57b8", null ],
+    [ "capabilities", "classproton_1_1target.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options-members.html
index 9c1e848..9345b00 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options-members.html
@@ -97,14 +97,15 @@ $(document).ready(function(){initNavTree('classproton_1_1target__options.html','
 <p>This is the complete list of members for <a class="el" href="classproton_1_1target__options.html">target_options</a>, including all inherited members.</p>
 <table class="directory">
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#a39a0acbf2c7de97e77df483ca9c4c6a9">address</a>(const std::string &amp;addr)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#a8ebe0e28560c7873712674314ac9547d">durability_mode</a>(enum target::durability_mode)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#acc2d56132d2a7a0b644429b78ff00756">dynamic</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#a3ee55474d84d67e826dc56f40b848b5b">expiry_policy</a>(enum target::expiry_policy)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#aa7c2b9b076f3d98fa3bc67d3bd4fcffd">operator=</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#add127463954d31c61475058fe14aef52">target_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#a19876222bb570ce8369d6024499faf05">target_options</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#a14a86cafc12d543ad6f9c3be88fbd7b6">timeout</a>(duration)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~target_options</b>() (defined in <a class="el" href="classproton_1_1target__options.html">target_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#aec90fa88e34bccd5a121baa6c7e9e95a">capabilities</a>(const std::vector&lt; symbol &gt; &amp;)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#a8ebe0e28560c7873712674314ac9547d">durability_mode</a>(enum target::durability_mode)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#acc2d56132d2a7a0b644429b78ff00756">dynamic</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#a3ee55474d84d67e826dc56f40b848b5b">expiry_policy</a>(enum target::expiry_policy)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#aa7c2b9b076f3d98fa3bc67d3bd4fcffd">operator=</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#add127463954d31c61475058fe14aef52">target_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1target__options.html#a19876222bb570ce8369d6024499faf05">target_options</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1target__options.html#a14a86cafc12d543ad6f9c3be88fbd7b6">timeout</a>(duration)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>~target_options</b>() (defined in <a class="el" href="classproton_1_1target__options.html">target_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1target__options.html">target_options</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.html
index c73316f..9d6e892 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.html
@@ -131,6 +131,10 @@ Public Member Functions</h2></td></tr>
 <tr class="memitem:a3ee55474d84d67e826dc56f40b848b5b"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1target__options.html">target_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1target__options.html#a3ee55474d84d67e826dc56f40b848b5b">expiry_policy</a> (enum <a class="el" href="classproton_1_1target.html#a348690a43df146eca928a8c06034a1eb">target::expiry_policy</a>)</td></tr>
 <tr class="memdesc:a3ee55474d84d67e826dc56f40b848b5b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Control when the clock for expiration begins.  <a href="#a3ee55474d84d67e826dc56f40b848b5b">More...</a><br /></td></tr>
 <tr class="separator:a3ee55474d84d67e826dc56f40b848b5b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aec90fa88e34bccd5a121baa6c7e9e95a"><td class="memItemLeft" align="right" valign="top"><a id="aec90fa88e34bccd5a121baa6c7e9e95a"></a>
+<a class="el" href="classproton_1_1target__options.html">target_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1target__options.html#aec90fa88e34bccd5a121baa6c7e9e95a">capabilities</a> (const std::vector&lt; <a class="el" href="classproton_1_1symbol.html">symbol</a> &gt; &amp;)</td></tr>
+<tr class="memdesc:aec90fa88e34bccd5a121baa6c7e9e95a"><td class="mdescLeft">&#160;</td><td class="mdescRight">Extension capabilities that are supported/requested. <br /></td></tr>
+<tr class="separator:aec90fa88e34bccd5a121baa6c7e9e95a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>Options for creating a target node for a sender or receiver. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.js
index 1971161..13f0b6f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1target__options.js
@@ -8,5 +8,6 @@ var classproton_1_1target__options =
     [ "dynamic", "classproton_1_1target__options.html#acc2d56132d2a7a0b644429b78ff00756", null ],
     [ "durability_mode", "classproton_1_1target__options.html#a8ebe0e28560c7873712674314ac9547d", null ],
     [ "timeout", "classproton_1_1target__options.html#a14a86cafc12d543ad6f9c3be88fbd7b6", null ],
-    [ "expiry_policy", "classproton_1_1target__options.html#a3ee55474d84d67e826dc56f40b848b5b", null ]
+    [ "expiry_policy", "classproton_1_1target__options.html#a3ee55474d84d67e826dc56f40b848b5b", null ],
+    [ "capabilities", "classproton_1_1target__options.html#aec90fa88e34bccd5a121baa6c7e9e95a", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus-members.html
index 49c0dda..c2c4a7c 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus-members.html
@@ -96,21 +96,22 @@ $(document).ready(function(){initNavTree('classproton_1_1terminus.html','');});
 
 <p>This is the complete list of members for <a class="el" href="classproton_1_1terminus.html">terminus</a>, including all inherited members.</p>
 <table class="directory">
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.html
index a6780ea..42fcec7 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.html
@@ -149,6 +149,10 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <tr class="memitem:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1value.html">value</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a> () const</td></tr>
 <tr class="memdesc:ab503c82e36aa618e6c6fb34feaad57b8"><td class="mdescLeft">&#160;</td><td class="mdescRight">Obtain a reference to the AMQP dynamic node properties for the terminus.  <a href="#ab503c82e36aa618e6c6fb34feaad57b8">More...</a><br /></td></tr>
 <tr class="separator:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memItemLeft" align="right" valign="top"><a id="a1c6bf68ea1dcbd3b2a0897adb628c1ee"></a>
+std::vector&lt; <a class="el" href="classproton_1_1symbol.html">symbol</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a> () const</td></tr>
+<tr class="memdesc:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="mdescLeft">&#160;</td><td class="mdescRight">Extension capabilities that are supported/requested. <br /></td></tr>
+<tr class="separator:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>One end of a link, either a source or a target. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.js
index 7e6a0d0..3d914ac 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1terminus.js
@@ -16,5 +16,6 @@ var classproton_1_1terminus =
     [ "timeout", "classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6", null ],
     [ "durability_mode", "classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8", null ],
     [ "dynamic", "classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec", null ],
-    [ "node_properties", "classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8", null ]
+    [ "node_properties", "classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8", null ],
+    [ "capabilities", "classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1tracker.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1tracker.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1tracker.html
index 0c73ff6..7976793 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1tracker.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1tracker.html
@@ -170,7 +170,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <div class="textblock"><p>A tracker for a sent message. </p>
 <p>Every tracker exists within the context of a sender.</p>
 <p>A delivery attempt can fail. As a result, a particular message may correspond to multiple trackers. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_send_8cpp-example.html#_a13">direct_send.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a16">helloworld_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a28">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a15">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_send_8cpp-example.html#_a12">direct_send.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a31">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a15">simple_send.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Enumeration Documentation</h2>
 <a id="adc6e5733fc3c22f0a7b2914188c49c90"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#adc6e5733fc3c22f0a7b2914188c49c90">&#9670;&nbsp;</a></span>state</h2>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1transport.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1transport.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1transport.html
index f0a12b9..a6dda06 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1transport.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1transport.html
@@ -135,7 +135,7 @@ class <a class="el" href="classproton_1_1error__condition.html">error_condition<
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A network channel supporting an AMQP connection. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a25">broker.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a18">direct_send.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a19">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a31">broker.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a16">direct_send.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a19">simple_send.cpp</a>.</dd>
 </dl></div><hr/>The documentation for this class was generated from the following file:<ul>
 <li>proton/<a class="el" href="transport_8hpp_source.html">transport.hpp</a></li>
 </ul>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1url.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1url.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1url.html
index bd84449..c62ec94 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1url.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1url.html
@@ -186,8 +186,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <li>Port can be a number or a symbolic service name such as <code>amqp</code>.</li>
 <li>Path is normally used as a link source or target address. On a broker it typically corresponds to a queue or topic name. </li>
 </ul>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="helloworld_8cpp-example.html#_a1">helloworld.cpp</a>, and <a class="el" href="server_8cpp-example.html#_a1">server.cpp</a>.</dd>
-</dl></div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
+</div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
 <a id="a2ac6e124f5c2a7a3c8464099b5c4fde7"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a2ac6e124f5c2a7a3c8464099b5c4fde7">&#9670;&nbsp;</a></span>url()</h2>
 

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1uuid.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1uuid.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1uuid.html
index 1bd9c73..9099db6 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1uuid.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1uuid.html
@@ -152,7 +152,7 @@ typedef std::reverse_iterator&lt; const_iterator &gt;&#160;</td><td class="memIt
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
 <tr class="memitem:ae9b08fca99a89639cd78a91152a64d5f"><td class="memItemLeft" align="right" valign="top">std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1uuid.html#ae9b08fca99a89639cd78a91152a64d5f">str</a> () const</td></tr>
-<tr class="memdesc:ae9b08fca99a89639cd78a91152a64d5f"><td class="mdescLeft">&#160;</td><td class="mdescRight">UUID standard string format: 8-4-4-4-12 (36 chars, 32 alphanumeric chars and 4 hypens).  <a href="#ae9b08fca99a89639cd78a91152a64d5f">More...</a><br /></td></tr>
+<tr class="memdesc:ae9b08fca99a89639cd78a91152a64d5f"><td class="mdescLeft">&#160;</td><td class="mdescRight">UUID standard string format: 8-4-4-4-12 (36 chars, 32 alphanumeric chars and 4 hyphens).  <a href="#ae9b08fca99a89639cd78a91152a64d5f">More...</a><br /></td></tr>
 <tr class="separator:ae9b08fca99a89639cd78a91152a64d5f"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr><td colspan="2"><div class="groupHeader">Array operators</div></td></tr>
 <tr class="memitem:a5cef60cb24e71a774ca7fd34a0299242"><td class="memItemLeft" align="right" valign="top"><a id="a5cef60cb24e71a774ca7fd34a0299242"></a>
@@ -267,7 +267,7 @@ static size_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" h
       </table>
 </div><div class="memdoc">
 
-<p>UUID standard string format: 8-4-4-4-12 (36 chars, 32 alphanumeric chars and 4 hypens). </p>
+<p>UUID standard string format: 8-4-4-4-12 (36 chars, 32 alphanumeric chars and 4 hyphens). </p>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1value.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1value.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1value.html
index 000adb0..98deec9 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1value.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1value.html
@@ -272,7 +272,7 @@ Related Functions</h2></td></tr>
   </table>
   </dd>
 </dl>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="service_bus_8cpp-example.html#a17">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="service_bus_8cpp-example.html#a19">service_bus.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue-members.html
index 08f5287..231455a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue-members.html
@@ -97,7 +97,9 @@ $(document).ready(function(){initNavTree('classproton_1_1work__queue.html','');}
 <p>This is the complete list of members for <a class="el" href="classproton_1_1work__queue.html">work_queue</a>, including all inherited members.</p>
 <table class="directory">
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(work fn)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601">schedule</a>(duration, work fn)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a7525d36e11cc3eb9d483e8e81713ab6d">add</a>(void_function0 &amp;fn)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601">schedule</a>(duration, work fn)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1work__queue.html#aee24365669f2a5d5906866d56c5b2a6e">schedule</a>(duration, void_function0 &amp;fn)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a1e7fdf3236c9477c0462214080c34689">work_queue</a>()</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1work__queue.html#a689e0d941a552db276229a9fc312e143">work_queue</a>(container &amp;)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>
   <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~work_queue</b>() (defined in <a class="el" href="classproton_1_1work__queue.html">work_queue</a>)</td><td class="entry"><a class="el" href="classproton_1_1work__queue.html">work_queue</a></td><td class="entry"></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.html
index b108974..2fa237c 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.html
@@ -112,18 +112,26 @@ Public Member Functions</h2></td></tr>
 &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a689e0d941a552db276229a9fc312e143">work_queue</a> (<a class="el" href="classproton_1_1container.html">container</a> &amp;)</td></tr>
 <tr class="memdesc:a689e0d941a552db276229a9fc312e143"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Create a work queue backed by a container. <br /></td></tr>
 <tr class="separator:a689e0d941a552db276229a9fc312e143"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a59dae2153455bc095477a3b66a0b681e"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a> (<a class="el" href="classproton_1_1work.html">work</a> fn)</td></tr>
+<tr class="memitem:a59dae2153455bc095477a3b66a0b681e"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a> (work fn)</td></tr>
 <tr class="memdesc:a59dae2153455bc095477a3b66a0b681e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Add work <code>fn</code> to the work queue.  <a href="#a59dae2153455bc095477a3b66a0b681e">More...</a><br /></td></tr>
 <tr class="separator:a59dae2153455bc095477a3b66a0b681e"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a214d82f5924296d6fddbb8b150f8b601"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a>, <a class="el" href="classproton_1_1work.html">work</a> fn)</td></tr>
+<tr class="memitem:a7525d36e11cc3eb9d483e8e81713ab6d"><td class="memItemLeft" align="right" valign="top"><a id="a7525d36e11cc3eb9d483e8e81713ab6d"></a>
+bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a7525d36e11cc3eb9d483e8e81713ab6d">add</a> (void_function0 &amp;fn)</td></tr>
+<tr class="memdesc:a7525d36e11cc3eb9d483e8e81713ab6d"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e" title="Unsettled API - Add work fn to the work queue. ">add(work)</a></code>. <br /></td></tr>
+<tr class="separator:a7525d36e11cc3eb9d483e8e81713ab6d"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a214d82f5924296d6fddbb8b150f8b601"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a>, work fn)</td></tr>
 <tr class="memdesc:a214d82f5924296d6fddbb8b150f8b601"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Add work <code>fn</code> to the work queue after a duration.  <a href="#a214d82f5924296d6fddbb8b150f8b601">More...</a><br /></td></tr>
 <tr class="separator:a214d82f5924296d6fddbb8b150f8b601"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aee24365669f2a5d5906866d56c5b2a6e"><td class="memItemLeft" align="right" valign="top"><a id="aee24365669f2a5d5906866d56c5b2a6e"></a>
+void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1work__queue.html#aee24365669f2a5d5906866d56c5b2a6e">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a>, void_function0 &amp;fn)</td></tr>
+<tr class="memdesc:aee24365669f2a5d5906866d56c5b2a6e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601" title="Unsettled API - Add work fn to the work queue after a duration. ">schedule(duration, work)</a></code>. <br /></td></tr>
+<tr class="separator:aee24365669f2a5d5906866d56c5b2a6e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p><b>Unsettled API</b> - A context for thread-safe execution of work. </p>
-<p>Event-handler functions associated with a single <code><a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a></code> are called in sequence. The connection's <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> allows you to "inject" extra <a class="el" href="classproton_1_1work.html">work</a> from any thread and have it executed in the same sequence.</p>
+<p>Event-handler functions associated with a single <code><a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a></code> are called in sequence. The connection's <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> allows you to "inject" extra work from any thread and have it executed in the same sequence.</p>
 <p>You may also create arbitrary <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> objects backed by a <a class="el" href="classproton_1_1container.html">container</a> that allow other objects to have their own serialised work queues that can have work injected safely from other threads. The <a class="el" href="classproton_1_1container.html">container</a> ensures that the work is correctly serialised.</p>
-<p>The <code><a class="el" href="classproton_1_1work.html" title="Unsettled API - A work item for a work queue. ">proton::work</a></code> class represents the work to be queued and can be created from a function that takes no parameters and returns no value. </p>
+<p>The <code>proton::work</code> class represents the work to be queued and can be created from a function that takes no parameters and returns no value. </p>
 <dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a2">broker.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a2">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a2">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a3">scheduled_send.cpp</a>, and <a class="el" href="scheduled_send_03_8cpp-example.html#_a2">scheduled_send_03.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a59dae2153455bc095477a3b66a0b681e"></a>
@@ -135,7 +143,7 @@ Public Member Functions</h2></td></tr>
         <tr>
           <td class="memname">bool add </td>
           <td>(</td>
-          <td class="paramtype"><a class="el" href="classproton_1_1work.html">work</a>&#160;</td>
+          <td class="paramtype">work&#160;</td>
           <td class="paramname"><em>fn</em></td><td>)</td>
           <td></td>
         </tr>
@@ -164,7 +172,7 @@ Public Member Functions</h2></td></tr>
         <tr>
           <td class="paramkey"></td>
           <td></td>
-          <td class="paramtype"><a class="el" href="classproton_1_1work.html">work</a>&#160;</td>
+          <td class="paramtype">work&#160;</td>
           <td class="paramname"><em>fn</em>&#160;</td>
         </tr>
         <tr>
@@ -179,7 +187,8 @@ Public Member Functions</h2></td></tr>
 <p>Scheduled execution is "best effort". It may not be possible to inject the work after the elapsed duration. There will be no indication of this.</p>
 <p>Work <code>fn</code> will be called serially with other work in the queue. The work may be deferred and executed in another thread.</p>
 <dl class="section return"><dt>Returns</dt><dd>true if <code>fn</code> has been or will be called; false if the event loops is ended or <code>fn</code> cannot be injected for any other reason. </dd></dl>
-
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="scheduled_send_03_8cpp-example.html#a10">scheduled_send_03.cpp</a>.</dd>
+</dl>
 </div>
 </div>
 <hr/>The documentation for this class was generated from the following file:<ul>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.js
index f716d1e..bc4ae11 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1work__queue.js
@@ -4,5 +4,7 @@ var classproton_1_1work__queue =
     [ "work_queue", "classproton_1_1work__queue.html#a689e0d941a552db276229a9fc312e143", null ],
     [ "~work_queue", "classproton_1_1work__queue.html#a0fd2d5e5a7950505283203b9c17ed5e7", null ],
     [ "add", "classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e", null ],
-    [ "schedule", "classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601", null ]
+    [ "add", "classproton_1_1work__queue.html#a7525d36e11cc3eb9d483e8e81713ab6d", null ],
+    [ "schedule", "classproton_1_1work__queue.html#a214d82f5924296d6fddbb8b150f8b601", null ],
+    [ "schedule", "classproton_1_1work__queue.html#aee24365669f2a5d5906866d56c5b2a6e", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/client_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/client_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/client_8cpp-example.html
index 0e8da97..cf9b49a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/client_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/client_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('client_8cpp-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>The client part of a request-response example. Sends requests and prints out responses. Requires an intermediary that supports the AMQP 1.0 dynamic nodes on which the responses are received. The requests are sent through the 'examples' node.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="source__options_8hpp.
 html">proton/source_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">using</span> <a name="_a0"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>;</div><div class="line"><span class="keyword">using</span> <a name="_a1"></a><a class="code" href="classproton_1_1source__options.html">proton::source_options</a>;</div><div class="line"></div><div class="line"><span class="keyword">class </span>client : <span class="keyword">public</span> <a name="_a2"></a><a class
 ="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    std::string url;</div><div class="line">    std::vector&lt;std::string&gt; requests;</div><div class="line">    <a name="_a3"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender;</div><div class="line">    <a name="_a4"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    client(<span class="keyword">const</span> std::string &amp;u, <span class="keyword">const</span> std::vector&lt;std::string&gt;&amp; r) : url(u), requests(r) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a5"></a><a class="code" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_contain
 er_start</a>(<a name="_a6"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        sender = c.<a name="a7"></a><a class="code" href="classproton_1_1container.html#adfbfd13668611a525bb44328d7a3b1e8">open_sender</a>(url);</div><div class="line">        <span class="comment">// Create a receiver requesting a dynamically created queue</span></div><div class="line">        <span class="comment">// for the message source.</span></div><div class="line">        receiver_options opts = receiver_options().source(source_options().dynamic(<span class="keyword">true</span>));</div><div class="line">        receiver = sender.<a name="a8"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a9"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(<span class="stringliteral">&quot;&quot;</span>, opts);</div><div 
 class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> send_request() {</div><div class="line">        <a name="_a10"></a><a class="code" href="classproton_1_1message.html">proton::message</a> req;</div><div class="line">        req.<a name="a11"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>(requests.front());</div><div class="line">        req.<a name="a12"></a><a class="code" href="classproton_1_1message.html#a4032b495d721bd6d29bfa33ebb8ac5fe">reply_to</a>(receiver.<a name="a13"></a><a class="code" href="classproton_1_1receiver.html#a91a9e8a9445b29d83dd0514cd76503ae">source</a>().<a name="a14"></a><a class="code" href="classproton_1_1source.html#a4744eb217c976c199b678bb5a0d55acf">address</a>());</div><div class="line">        sender.<a name="a15"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(req);</div><div class="line">    }</
 div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a16"></a><a class="code" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd">on_receiver_open</a>(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> &amp;) OVERRIDE {</div><div class="line">        send_request();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a17"></a><a class="code" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a>(<a name="_a18"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;response) OVERRIDE {</div><div class="line">        <span class="keywordflow">if</span> (requests.empty()) <span class="keywordflow">return</span>; <span class="comment">// Spurious extra message!</span></div><div
  class="line"></div><div class="line">        std::cout &lt;&lt; requests.front() &lt;&lt; <span class="stringliteral">&quot; =&gt; &quot;</span> &lt;&lt; response.<a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">        requests.erase(requests.begin());</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (!requests.empty()) {</div><div class="line">            send_request();</div><div class="line">        } <span class="keywordflow">else</span> {</div><div class="line">            d.<a name="a19"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a20"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><sp
 an class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string url(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(url, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;connect and send to URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        std::vector&lt;std::string&gt; requests;</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;Twas brillig, and the slithy toves&quot;</span>);</div><div class="line">   
      requests.push_back(<span class="stringliteral">&quot;Did gire and gymble in the wabe.&quot;</span>);</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;All mimsy were the borogroves,&quot;</span>);</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;And the mome raths outgrabe.&quot;</span>);</div><div class="line"></div><div class="line">        client c(url, requests);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(c).<a name="a21"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;
 &lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="source__options_8hpp.
 html">proton/source_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">using</span> <a name="_a0"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>;</div><div class="line"><span class="keyword">using</span> <a name="_a1"></a><a class="code" href="classproton_1_1source__options.html">proton::source_options</a>;</div><div class="line"></div><div class="line"><span class="keyword">class </span>client : <span class="keyword">public</span> <a name="_a2"></a><a class
 ="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    std::string url;</div><div class="line">    std::vector&lt;std::string&gt; requests;</div><div class="line">    <a name="_a3"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender;</div><div class="line">    <a name="_a4"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    client(<span class="keyword">const</span> std::string &amp;u, <span class="keyword">const</span> std::vector&lt;std::string&gt;&amp; r) : url(u), requests(r) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a5"></a><a class="code" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">on_contain
 er_start</a>(<a name="_a6"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        sender = c.<a name="a7"></a><a class="code" href="classproton_1_1container.html#adfbfd13668611a525bb44328d7a3b1e8">open_sender</a>(url);</div><div class="line">        <span class="comment">// Create a receiver requesting a dynamically created queue</span></div><div class="line">        <span class="comment">// for the message source.</span></div><div class="line">        receiver_options opts = receiver_options().source(source_options().dynamic(<span class="keyword">true</span>));</div><div class="line">        receiver = sender.<a name="a8"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a9"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(<span class="stringliteral">&quot;&quot;</span>, opts);</div><div 
 class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> send_request() {</div><div class="line">        <a name="_a10"></a><a class="code" href="classproton_1_1message.html">proton::message</a> req;</div><div class="line">        req.<a name="a11"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>(requests.front());</div><div class="line">        req.<a name="a12"></a><a class="code" href="classproton_1_1message.html#a4032b495d721bd6d29bfa33ebb8ac5fe">reply_to</a>(receiver.<a name="a13"></a><a class="code" href="classproton_1_1receiver.html#a91a9e8a9445b29d83dd0514cd76503ae">source</a>().<a name="a14"></a><a class="code" href="classproton_1_1source.html#a4744eb217c976c199b678bb5a0d55acf">address</a>());</div><div class="line">        sender.<a name="a15"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(req);</div><div class="line">    }</
 div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a16"></a><a class="code" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401">on_receiver_open</a>(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> &amp;) OVERRIDE {</div><div class="line">        send_request();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a17"></a><a class="code" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">on_message</a>(<a name="_a18"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;response) OVERRIDE {</div><div class="line">        <span class="keywordflow">if</span> (requests.empty()) <span class="keywordflow">return</span>; <span class="comment">// Spurious extra message!</span></div><div
  class="line"></div><div class="line">        std::cout &lt;&lt; requests.front() &lt;&lt; <span class="stringliteral">&quot; =&gt; &quot;</span> &lt;&lt; response.<a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">        requests.erase(requests.begin());</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (!requests.empty()) {</div><div class="line">            send_request();</div><div class="line">        } <span class="keywordflow">else</span> {</div><div class="line">            d.<a name="a19"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a20"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><sp
 an class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string url(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(url, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;connect and send to URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        std::vector&lt;std::string&gt; requests;</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;Twas brillig, and the slithy toves&quot;</span>);</div><div class="line">   
      requests.push_back(<span class="stringliteral">&quot;Did gire and gymble in the wabe.&quot;</span>);</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;All mimsy were the borogroves,&quot;</span>);</div><div class="line">        requests.push_back(<span class="stringliteral">&quot;And the mome raths outgrabe.&quot;</span>);</div><div class="line"></div><div class="line">        client c(url, requests);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(c).<a name="a21"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;
 &lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[44/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/event_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/event_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/event_8h_source.html
index 65ac27f..e24af5f 100755
--- a/content/releases/qpid-proton-master/proton/c/api/event_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/event_8h_source.html
@@ -109,14 +109,14 @@ $(document).ready(function(){initNavTree('event_8h_source.html','');});
 <div class="ttc" id="group__event_html_gae7beda7f373660b889b61412ce429028"><div class="ttname"><a href="group__event.html#gae7beda7f373660b889b61412ce429028">pn_event_condition</a></div><div class="ttdeci">struct pn_condition_t * pn_event_condition(pn_event_t *event)</div><div class="ttdoc">If the event context object has a condition and the condition is set return it, otherwise return NULL...</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498">PN_CONNECTION_UNBOUND</a></div><div class="ttdoc">The connection has been unbound from its transport. </div><div class="ttdef"><b>Definition:</b> event.h:125</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e">PN_LINK_LOCAL_DETACH</a></div><div class="ttdoc">The local link endpoint has been detached. </div><div class="ttdef"><b>Definition:</b> event.h:229</div></div>
-<div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a></div><div class="ttdoc">The listener is listeneing. </div><div class="ttdef"><b>Definition:</b> event.h:350</div></div>
+<div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a></div><div class="ttdoc">The listener is listening. </div><div class="ttdef"><b>Definition:</b> event.h:350</div></div>
 <div class="ttc" id="group__event_html_gadab22668a28ff1af0d8ef82df516f94f"><div class="ttname"><a href="group__event.html#gadab22668a28ff1af0d8ef82df516f94f">pn_collector_drain</a></div><div class="ttdeci">void pn_collector_drain(pn_collector_t *collector)</div><div class="ttdoc">Drain a collector: remove and discard all events. </div></div>
-<div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a></div><div class="ttdoc">Indicates the listener has an incoming connection, call pn_listener_accept() to accept it...</div><div class="ttdef"><b>Definition:</b> event.h:316</div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a></div><div class="ttdoc">Indicates the listener has an incoming connection, call pn_listener_accept2() to accept it...</div><div class="ttdef"><b>Definition:</b> event.h:316</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__event_html_ga10fa6f53bdabe0851ebb2d8a0bf6a52c"><div class="ttname"><a href="group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a></div><div class="ttdeci">pn_delivery_t * pn_event_delivery(pn_event_t *event)</div><div class="ttdoc">Get the delivery associated with an event. </div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c">PN_LINK_INIT</a></div><div class="ttdoc">The link has been created. </div><div class="ttdef"><b>Definition:</b> event.h:199</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86">PN_CONNECTION_LOCAL_CLOSE</a></div><div class="ttdoc">The local connection endpoint has been closed. </div><div class="ttdef"><b>Definition:</b> event.h:143</div></div>
-<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:313</div></div>
+<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:311</div></div>
 <div class="ttc" id="group__event_html_ga6bc581dfeaa8e8d46d07d37229d565c9"><div class="ttname"><a href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a></div><div class="ttdeci">struct pn_event_batch_t pn_event_batch_t</div><div class="ttdoc">Unsettled API - A batch of events that must be handled in sequence. </div><div class="ttdef"><b>Definition:</b> event.h:547</div></div>
 <div class="ttc" id="group__event_html_ga5989cf0c187bd12899596fe06931476e"><div class="ttname"><a href="group__event.html#ga5989cf0c187bd12899596fe06931476e">pn_event_attachments</a></div><div class="ttdeci">pn_record_t * pn_event_attachments(pn_event_t *event)</div><div class="ttdoc">Get any attachments associated with an event. </div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a></div><div class="ttdoc">A delivery has been created or updated. </div><div class="ttdef"><b>Definition:</b> event.h:254</div></div>
@@ -125,9 +125,9 @@ $(document).ready(function(){initNavTree('event_8h_source.html','');});
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db">PN_TRANSPORT_TAIL_CLOSED</a></div><div class="ttdoc">Indicates that the tail of the transport has been closed. </div><div class="ttdef"><b>Definition:</b> event.h:289</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657">PN_EVENT_NONE</a></div><div class="ttdoc">Defined as a programming convenience. </div><div class="ttdef"><b>Definition:</b> event.h:85</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0">PN_CONNECTION_WAKE</a></div><div class="ttdoc">pn_connection_wake() was called. </div><div class="ttdef"><b>Definition:</b> event.h:309</div></div>
-<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:415</div></div>
+<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
 <div class="ttc" id="group__event_html_ga9304e9c2e85cb5de23c81ae7cd8a9077"><div class="ttname"><a href="group__event.html#ga9304e9c2e85cb5de23c81ae7cd8a9077">pn_collector_prev</a></div><div class="ttdeci">pn_event_t * pn_collector_prev(pn_collector_t *collector)</div><div class="ttdoc">Return the same pointer as the most recent call to pn_collector_next(). </div></div>
-<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:294</div></div>
+<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:292</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e">PN_CONNECTION_INIT</a></div><div class="ttdoc">The connection has been created. </div><div class="ttdef"><b>Definition:</b> event.h:113</div></div>
 <div class="ttc" id="group__event_html_ga7c7754316e257d4ce7660730953000ac"><div class="ttname"><a href="group__event.html#ga7c7754316e257d4ce7660730953000ac">pn_collector</a></div><div class="ttdeci">pn_collector_t * pn_collector(void)</div><div class="ttdoc">Construct a collector. </div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe">PN_PROACTOR_TIMEOUT</a></div><div class="ttdoc">Timeout set by pn_proactor_set_timeout() time limit expired. </div><div class="ttdef"><b>Definition:</b> event.h:334</div></div>
@@ -136,7 +136,7 @@ $(document).ready(function(){initNavTree('event_8h_source.html','');});
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a">PN_CONNECTION_LOCAL_OPEN</a></div><div class="ttdoc">The local connection endpoint has been closed. </div><div class="ttdef"><b>Definition:</b> event.h:131</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f">PN_SESSION_INIT</a></div><div class="ttdoc">The session has been created. </div><div class="ttdef"><b>Definition:</b> event.h:162</div></div>
 <div class="ttc" id="group__event_html_gaecda1dea7e3a01c4ba246043ea438b19"><div class="ttname"><a href="group__event.html#gaecda1dea7e3a01c4ba246043ea438b19">pn_event_context</a></div><div class="ttdeci">void * pn_event_context(pn_event_t *event)</div><div class="ttdoc">Get the context associated with an event. </div></div>
-<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:403</div></div>
+<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:401</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db">PN_REACTOR_INIT</a></div><div class="ttdoc">A reactor has been started. </div><div class="ttdef"><b>Definition:</b> event.h:90</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc">PN_CONNECTION_REMOTE_OPEN</a></div><div class="ttdoc">The remote endpoint has opened the connection. </div><div class="ttdef"><b>Definition:</b> event.h:137</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5">PN_LINK_FINAL</a></div><div class="ttdoc">The link has been freed and any outstanding processing has been completed. </div><div class="ttdef"><b>Definition:</b> event.h:248</div></div>
@@ -148,7 +148,7 @@ $(document).ready(function(){initNavTree('event_8h_source.html','');});
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51">PN_TRANSPORT_HEAD_CLOSED</a></div><div class="ttdoc">Indicates that the &quot;head&quot; or writing end of the transport has been closed. </div><div class="ttdef"><b>Definition:</b> event.h:282</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca">PN_LISTENER_CLOSE</a></div><div class="ttdoc">Indicates the listener has closed. </div><div class="ttdef"><b>Definition:</b> event.h:322</div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307">PN_LINK_REMOTE_OPEN</a></div><div class="ttdoc">The remote endpoint has opened the link. </div><div class="ttdef"><b>Definition:</b> event.h:211</div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__event_html_gac3fbf151357d3101ac294cb675348c76"><div class="ttname"><a href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a></div><div class="ttdeci">pn_event_t * pn_event_batch_next(pn_event_batch_t *batch)</div><div class="ttdoc">Unsettled API - Remove the next event from the batch and return it. </div></div>
 <div class="ttc" id="group__event_html_ga3a85c046c11ce692c23b9566b022d54b"><div class="ttname"><a href="group__event.html#ga3a85c046c11ce692c23b9566b022d54b">pn_event_type_name</a></div><div class="ttdeci">const char * pn_event_type_name(pn_event_type_t type)</div><div class="ttdoc">Get a human readable name for an event type. </div></div>
 <div class="ttc" id="group__event_html_gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499"><div class="ttname"><a href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499">PN_PROACTOR_INTERRUPT</a></div><div class="ttdoc">Indicates pn_proactor_interrupt() was called to interrupt a proactor thread. </div><div class="ttdef"><b>Definition:</b> event.h:328</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/files.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/files.html b/content/releases/qpid-proton-master/proton/c/api/files.html
index 39e502f..b42ff75 100755
--- a/content/releases/qpid-proton-master/proton/c/api/files.html
+++ b/content/releases/qpid-proton-master/proton/c/api/files.html
@@ -96,27 +96,37 @@ $(document).ready(function(){initNavTree('files.html','');});
 <div class="textblock">Here is a list of all documented files with brief descriptions:</div><div class="directory">
 <div class="levels">[detail level <span onclick="javascript:toggleLevel(1);">1</span><span onclick="javascript:toggleLevel(2);">2</span>]</div><table class="directory">
 <tr id="row_0_" class="even"><td class="entry"><span style="width:0px;display:inline-block;">&#160;</span><span id="arr_0_" class="arrow" onclick="toggleFolder('0_')">&#9660;</span><span id="img_0_" class="iconfopen" onclick="toggleFolder('0_')">&#160;</span><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html" target="_self">proton</a></td><td class="desc"></td></tr>
-<tr id="row_0_0_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="codec_8h_source.html"><span class="icondoc"></span></a><a class="el" href="codec_8h.html" target="_self">codec.h</a></td><td class="desc">AMQP data encoding and decoding. </td></tr>
-<tr id="row_0_1_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="condition_8h_source.html"><span class="icondoc"></span></a><a class="el" href="condition_8h.html" target="_self">condition.h</a></td><td class="desc">An endpoint error state. </td></tr>
-<tr id="row_0_2_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="connection_8h_source.html"><span class="icondoc"></span></a><a class="el" href="connection_8h.html" target="_self">connection.h</a></td><td class="desc">A connection to a remote AMQP peer. </td></tr>
-<tr id="row_0_3_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="connection__driver_8h_source.html"><span class="icondoc"></span></a><a class="el" href="connection__driver_8h.html" target="_self">connection_driver.h</a></td><td class="desc"><b>Unsettled API</b> - An API for low-level IO integration. </td></tr>
-<tr id="row_0_4_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="delivery_8h_source.html"><span class="icondoc"></span></a><a class="el" href="delivery_8h.html" target="_self">delivery.h</a></td><td class="desc">A message transfer. </td></tr>
-<tr id="row_0_5_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="disposition_8h_source.html"><span class="icondoc"></span></a><a class="el" href="disposition_8h.html" target="_self">disposition.h</a></td><td class="desc">A delivery state. </td></tr>
-<tr id="row_0_6_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="error_8h_source.html"><span class="icondoc"></span></a><a class="el" href="error_8h.html" target="_self">error.h</a></td><td class="desc">A Proton API error. </td></tr>
-<tr id="row_0_7_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="event_8h_source.html"><span class="icondoc"></span></a><a class="el" href="event_8h.html" target="_self">event.h</a></td><td class="desc">Protocol and transport events. </td></tr>
-<tr id="row_0_8_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="link_8h_source.html"><span class="icondoc"></span></a><a class="el" href="link_8h.html" target="_self">link.h</a></td><td class="desc">A channel for transferring messages. </td></tr>
-<tr id="row_0_9_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="listener_8h_source.html"><span class="icondoc"></span></a><a class="el" href="listener_8h.html" target="_self">listener.h</a></td><td class="desc"><b>Unsettled API</b> - A listener for incoming connections. </td></tr>
-<tr id="row_0_10_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="message_8h_source.html"><span class="icondoc"></span></a><a class="el" href="message_8h.html" target="_self">message.h</a></td><td class="desc">A mutable holder of application content. </td></tr>
-<tr id="row_0_11_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="messenger_8h_source.html"><span class="icondoc"></span></a><a class="el" href="messenger_8h.html" target="_self">messenger.h</a></td><td class="desc"><b>Deprecated</b> - Use the <a class="el" href="group__proactor.html">Proactor</a> API or Qpid Proton C++. </td></tr>
-<tr id="row_0_12_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="netaddr_8h_source.html"><span class="icondoc"></span></a><a class="el" href="netaddr_8h.html" target="_self">netaddr.h</a></td><td class="desc"><b>Unsettled API</b> - The network address of a proactor transport. </td></tr>
-<tr id="row_0_13_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="proactor_8h_source.html"><span class="icondoc"></span></a><a class="el" href="proactor_8h.html" target="_self">proactor.h</a></td><td class="desc"><b>Unsettled API</b> - An API for multithreaded IO. </td></tr>
-<tr id="row_0_14_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sasl_8h_source.html"><span class="icondoc"></span></a><a class="el" href="sasl_8h.html" target="_self">sasl.h</a></td><td class="desc">SASL secure transport layer. </td></tr>
-<tr id="row_0_15_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session_8h_source.html"><span class="icondoc"></span></a><a class="el" href="session_8h.html" target="_self">session.h</a></td><td class="desc">A container of links. </td></tr>
-<tr id="row_0_16_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="ssl_8h_source.html"><span class="icondoc"></span></a><a class="el" href="ssl_8h.html" target="_self">ssl.h</a></td><td class="desc">SSL secure transport layer. </td></tr>
-<tr id="row_0_17_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="terminus_8h_source.html"><span class="icondoc"></span></a><a class="el" href="terminus_8h.html" target="_self">terminus.h</a></td><td class="desc">A source or target for messages. </td></tr>
-<tr id="row_0_18_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transport_8h_source.html"><span class="icondoc"></span></a><a class="el" href="transport_8h.html" target="_self">transport.h</a></td><td class="desc">A network channel supporting an AMQP connection. </td></tr>
-<tr id="row_0_19_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types_8h_source.html"><span class="icondoc"></span></a><a class="el" href="types_8h.html" target="_self">types.h</a></td><td class="desc">AMQP and API data types. </td></tr>
-<tr id="row_0_20_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="url_8h_source.html"><span class="icondoc"></span></a><a class="el" href="url_8h.html" target="_self">url.h</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library. </td></tr>
+<tr id="row_0_0_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="cid_8h_source.html"><span class="icondoc"></span></a><b>cid.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_1_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="codec_8h_source.html"><span class="icondoc"></span></a><a class="el" href="codec_8h.html" target="_self">codec.h</a></td><td class="desc">AMQP data encoding and decoding. </td></tr>
+<tr id="row_0_2_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="condition_8h_source.html"><span class="icondoc"></span></a><a class="el" href="condition_8h.html" target="_self">condition.h</a></td><td class="desc">An endpoint error state. </td></tr>
+<tr id="row_0_3_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="connection_8h_source.html"><span class="icondoc"></span></a><a class="el" href="connection_8h.html" target="_self">connection.h</a></td><td class="desc">A connection to a remote AMQP peer. </td></tr>
+<tr id="row_0_4_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="connection__driver_8h_source.html"><span class="icondoc"></span></a><a class="el" href="connection__driver_8h.html" target="_self">connection_driver.h</a></td><td class="desc"><b>Unsettled API</b> - An API for low-level IO integration. </td></tr>
+<tr id="row_0_5_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="delivery_8h_source.html"><span class="icondoc"></span></a><a class="el" href="delivery_8h.html" target="_self">delivery.h</a></td><td class="desc">A message transfer. </td></tr>
+<tr id="row_0_6_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="disposition_8h_source.html"><span class="icondoc"></span></a><a class="el" href="disposition_8h.html" target="_self">disposition.h</a></td><td class="desc">A delivery state. </td></tr>
+<tr id="row_0_7_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="engine_8h_source.html"><span class="icondoc"></span></a><b>engine.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_8_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="error_8h_source.html"><span class="icondoc"></span></a><a class="el" href="error_8h.html" target="_self">error.h</a></td><td class="desc">A Proton API error. </td></tr>
+<tr id="row_0_9_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="event_8h_source.html"><span class="icondoc"></span></a><a class="el" href="event_8h.html" target="_self">event.h</a></td><td class="desc">Protocol and transport events. </td></tr>
+<tr id="row_0_10_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="handlers_8h_source.html"><span class="icondoc"></span></a><b>handlers.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_11_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="import__export_8h_source.html"><span class="icondoc"></span></a><b>import_export.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_12_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="link_8h_source.html"><span class="icondoc"></span></a><a class="el" href="link_8h.html" target="_self">link.h</a></td><td class="desc">A channel for transferring messages. </td></tr>
+<tr id="row_0_13_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="listener_8h_source.html"><span class="icondoc"></span></a><a class="el" href="listener_8h.html" target="_self">listener.h</a></td><td class="desc"><b>Unsettled API</b> - A listener for incoming connections. </td></tr>
+<tr id="row_0_14_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="log_8h_source.html"><span class="icondoc"></span></a><b>log.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_15_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="message_8h_source.html"><span class="icondoc"></span></a><a class="el" href="message_8h.html" target="_self">message.h</a></td><td class="desc">A mutable holder of application content. </td></tr>
+<tr id="row_0_16_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="messenger_8h_source.html"><span class="icondoc"></span></a><a class="el" href="messenger_8h.html" target="_self">messenger.h</a></td><td class="desc"><b>Deprecated</b> - Use the <a class="el" href="group__proactor.html">Proactor</a> API or Qpid Proton C++. </td></tr>
+<tr id="row_0_17_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="netaddr_8h_source.html"><span class="icondoc"></span></a><a class="el" href="netaddr_8h.html" target="_self">netaddr.h</a></td><td class="desc"><b>Unsettled API</b> - The network address of a proactor transport. </td></tr>
+<tr id="row_0_18_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="object_8h_source.html"><span class="icondoc"></span></a><b>object.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_19_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="proactor_8h_source.html"><span class="icondoc"></span></a><a class="el" href="proactor_8h.html" target="_self">proactor.h</a></td><td class="desc"><b>Unsettled API</b> - An API for multithreaded IO. </td></tr>
+<tr id="row_0_20_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="reactor_8h_source.html"><span class="icondoc"></span></a><b>reactor.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_21_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sasl-plugin_8h_source.html"><span class="icondoc"></span></a><b>sasl-plugin.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_22_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sasl_8h_source.html"><span class="icondoc"></span></a><a class="el" href="sasl_8h.html" target="_self">sasl.h</a></td><td class="desc">SASL secure transport layer. </td></tr>
+<tr id="row_0_23_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="selectable_8h_source.html"><span class="icondoc"></span></a><b>selectable.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_24_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session_8h_source.html"><span class="icondoc"></span></a><a class="el" href="session_8h.html" target="_self">session.h</a></td><td class="desc">A container of links. </td></tr>
+<tr id="row_0_25_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="ssl_8h_source.html"><span class="icondoc"></span></a><a class="el" href="ssl_8h.html" target="_self">ssl.h</a></td><td class="desc">SSL secure transport layer. </td></tr>
+<tr id="row_0_26_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="terminus_8h_source.html"><span class="icondoc"></span></a><a class="el" href="terminus_8h.html" target="_self">terminus.h</a></td><td class="desc">A source or target for messages. </td></tr>
+<tr id="row_0_27_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transport_8h_source.html"><span class="icondoc"></span></a><a class="el" href="transport_8h.html" target="_self">transport.h</a></td><td class="desc">A network channel supporting an AMQP connection. </td></tr>
+<tr id="row_0_28_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="type__compat_8h_source.html"><span class="icondoc"></span></a><b>type_compat.h</b></td><td class="desc"></td></tr>
+<tr id="row_0_29_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types_8h_source.html"><span class="icondoc"></span></a><a class="el" href="types_8h.html" target="_self">types.h</a></td><td class="desc">AMQP and API data types. </td></tr>
+<tr id="row_0_30_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="url_8h_source.html"><span class="icondoc"></span></a><a class="el" href="url_8h.html" target="_self">url.h</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library. </td></tr>
 </table>
 </div><!-- directory -->
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals.html b/content/releases/qpid-proton-master/proton/c/api/globals.html
index e413af5..19d2210 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals.html
@@ -92,6 +92,9 @@ $(document).ready(function(){initNavTree('globals.html','');});
 <div class="textblock">Here is a list of all documented file members with links to the documentation:</div>
 
 <h3><a id="index_a"></a>- a -</h3><ul>
+<li>PN_ABORTED
+: <a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0">error.h</a>
+</li>
 <li>PN_ACCEPTED
 : <a class="el" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">disposition.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_c.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_c.html b/content/releases/qpid-proton-master/proton/c/api/globals_c.html
index bd2acde..510b47f 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_c.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_c.html
@@ -239,6 +239,9 @@ $(document).ready(function(){initNavTree('globals_c.html','');});
 <li>pn_connection_driver_next_event()
 : <a class="el" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">connection_driver.h</a>
 </li>
+<li>pn_connection_driver_ptr()
+: <a class="el" href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">connection_driver.h</a>
+</li>
 <li>pn_connection_driver_read_buffer()
 : <a class="el" href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438">connection_driver.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_defs.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_defs.html b/content/releases/qpid-proton-master/proton/c/api/globals_defs.html
index 3803b21..214cf6c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_defs.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_defs.html
@@ -92,6 +92,9 @@ $(document).ready(function(){initNavTree('globals_defs.html','');});
 &#160;
 
 <h3><a id="index_a"></a>- a -</h3><ul>
+<li>PN_ABORTED
+: <a class="el" href="group__error.html#ga82db456291c2627e31becc44b733a7f0">error.h</a>
+</li>
 <li>PN_ACCEPTED
 : <a class="el" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">disposition.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_c.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_c.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_c.html
index 3e7c327..928ae7d 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_c.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_c.html
@@ -221,6 +221,9 @@ $(document).ready(function(){initNavTree('globals_func_c.html','');});
 <li>pn_connection_driver_next_event()
 : <a class="el" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">connection_driver.h</a>
 </li>
+<li>pn_connection_driver_ptr()
+: <a class="el" href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">connection_driver.h</a>
+</li>
 <li>pn_connection_driver_read_buffer()
 : <a class="el" href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438">connection_driver.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_l.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_l.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_l.html
index 71e26b7..cfafe01 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_l.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_l.html
@@ -234,7 +234,13 @@ $(document).ready(function(){initNavTree('globals_func_l.html','');});
 : <a class="el" href="group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5">listener.h</a>
 </li>
 <li>pn_listener_accept()
-: <a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">listener.h</a>
+: <a class="el" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">listener.h</a>
+</li>
+<li>pn_listener_accept2()
+: <a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">listener.h</a>
+</li>
+<li>pn_listener_addr()
+: <a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">netaddr.h</a>
 </li>
 <li>pn_listener_attachments()
 : <a class="el" href="group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f">listener.h</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_m.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_m.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_m.html
index 57e8840..acf8ea7 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_m.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_m.html
@@ -191,6 +191,9 @@ $(document).ready(function(){initNavTree('globals_func_m.html','');});
 <li>pn_message_properties()
 : <a class="el" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">message.h</a>
 </li>
+<li>pn_message_send()
+: <a class="el" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">message.h</a>
+</li>
 <li>pn_message_set_address()
 : <a class="el" href="group__message.html#ga38ecee233f94e128bed9be3e530f27e5">message.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_n.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_n.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_n.html
index e8d789f..b696513 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_n.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_n.html
@@ -92,9 +92,18 @@ $(document).ready(function(){initNavTree('globals_func_n.html','');});
 &#160;
 
 <h3><a id="index_n"></a>- n -</h3><ul>
+<li>pn_netaddr_host_port()
+: <a class="el" href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">netaddr.h</a>
+</li>
+<li>pn_netaddr_listening()
+: <a class="el" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">netaddr.h</a>
+</li>
 <li>pn_netaddr_local()
 : <a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">netaddr.h</a>
 </li>
+<li>pn_netaddr_next()
+: <a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">netaddr.h</a>
+</li>
 <li>pn_netaddr_remote()
 : <a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">netaddr.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_p.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_p.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_p.html
index b72fcf3..6cb3cc5 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_p.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_p.html
@@ -104,6 +104,9 @@ $(document).ready(function(){initNavTree('globals_func_p.html','');});
 <li>pn_proactor_connect()
 : <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">proactor.h</a>
 </li>
+<li>pn_proactor_connect2()
+: <a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">proactor.h</a>
+</li>
 <li>pn_proactor_disconnect()
 : <a class="el" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68">proactor.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_s.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_s.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_s.html
index c06133f..14b62bb 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_s.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_s.html
@@ -200,12 +200,18 @@ $(document).ready(function(){initNavTree('globals_func_s.html','');});
 <li>pn_ssl_domain_free()
 : <a class="el" href="group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d">ssl.h</a>
 </li>
+<li>pn_ssl_domain_set_ciphers()
+: <a class="el" href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">ssl.h</a>
+</li>
 <li>pn_ssl_domain_set_credentials()
 : <a class="el" href="group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa">ssl.h</a>
 </li>
 <li>pn_ssl_domain_set_peer_authentication()
 : <a class="el" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">ssl.h</a>
 </li>
+<li>pn_ssl_domain_set_protocols()
+: <a class="el" href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">ssl.h</a>
+</li>
 <li>pn_ssl_domain_set_trusted_ca_db()
 : <a class="el" href="group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d">ssl.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_func_t.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_func_t.html b/content/releases/qpid-proton-master/proton/c/api/globals_func_t.html
index fd4b7b6..6ef1e1b 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_func_t.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_func_t.html
@@ -227,6 +227,9 @@ $(document).ready(function(){initNavTree('globals_func_t.html','');});
 <li>pn_transport_is_encrypted()
 : <a class="el" href="group__transport.html#ga737021ca419e948932071aad2ad38c5b">transport.h</a>
 </li>
+<li>pn_transport_local_addr()
+: <a class="el" href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">netaddr.h</a>
+</li>
 <li>pn_transport_log()
 : <a class="el" href="group__transport.html#gad603e8d72578bcedd2d9235f74f28f37">transport.h</a>
 </li>
@@ -254,6 +257,9 @@ $(document).ready(function(){initNavTree('globals_func_t.html','');});
 <li>pn_transport_quiesced()
 : <a class="el" href="group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef">transport.h</a>
 </li>
+<li>pn_transport_remote_addr()
+: <a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">netaddr.h</a>
+</li>
 <li>pn_transport_remote_channel_max()
 : <a class="el" href="group__transport.html#gaff7c08aeb92596ad9d269468d1557647">transport.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_l.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_l.html b/content/releases/qpid-proton-master/proton/c/api/globals_l.html
index 0657f3c..76c0051 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_l.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_l.html
@@ -270,7 +270,13 @@ $(document).ready(function(){initNavTree('globals_l.html','');});
 : <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">event.h</a>
 </li>
 <li>pn_listener_accept()
-: <a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">listener.h</a>
+: <a class="el" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">listener.h</a>
+</li>
+<li>pn_listener_accept2()
+: <a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">listener.h</a>
+</li>
+<li>pn_listener_addr()
+: <a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">netaddr.h</a>
 </li>
 <li>pn_listener_attachments()
 : <a class="el" href="group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f">listener.h</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_m.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_m.html b/content/releases/qpid-proton-master/proton/c/api/globals_m.html
index 80b1c89..3601c60 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_m.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_m.html
@@ -197,6 +197,9 @@ $(document).ready(function(){initNavTree('globals_m.html','');});
 <li>pn_message_properties()
 : <a class="el" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">message.h</a>
 </li>
+<li>pn_message_send()
+: <a class="el" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">message.h</a>
+</li>
 <li>pn_message_set_address()
 : <a class="el" href="group__message.html#ga38ecee233f94e128bed9be3e530f27e5">message.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_n.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_n.html b/content/releases/qpid-proton-master/proton/c/api/globals_n.html
index ec9b67c..762352c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_n.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_n.html
@@ -92,9 +92,18 @@ $(document).ready(function(){initNavTree('globals_n.html','');});
 <div class="textblock">Here is a list of all documented file members with links to the documentation:</div>
 
 <h3><a id="index_n"></a>- n -</h3><ul>
+<li>pn_netaddr_host_port()
+: <a class="el" href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">netaddr.h</a>
+</li>
+<li>pn_netaddr_listening()
+: <a class="el" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">netaddr.h</a>
+</li>
 <li>pn_netaddr_local()
 : <a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">netaddr.h</a>
 </li>
+<li>pn_netaddr_next()
+: <a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">netaddr.h</a>
+</li>
 <li>pn_netaddr_remote()
 : <a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">netaddr.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_p.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_p.html b/content/releases/qpid-proton-master/proton/c/api/globals_p.html
index e49ef44..256b64a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_p.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_p.html
@@ -104,6 +104,9 @@ $(document).ready(function(){initNavTree('globals_p.html','');});
 <li>pn_proactor_connect()
 : <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">proactor.h</a>
 </li>
+<li>pn_proactor_connect2()
+: <a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">proactor.h</a>
+</li>
 <li>pn_proactor_disconnect()
 : <a class="el" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68">proactor.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_s.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_s.html b/content/releases/qpid-proton-master/proton/c/api/globals_s.html
index ad7ed40..74db6b1 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_s.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_s.html
@@ -272,12 +272,18 @@ $(document).ready(function(){initNavTree('globals_s.html','');});
 <li>pn_ssl_domain_free()
 : <a class="el" href="group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d">ssl.h</a>
 </li>
+<li>pn_ssl_domain_set_ciphers()
+: <a class="el" href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">ssl.h</a>
+</li>
 <li>pn_ssl_domain_set_credentials()
 : <a class="el" href="group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa">ssl.h</a>
 </li>
 <li>pn_ssl_domain_set_peer_authentication()
 : <a class="el" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">ssl.h</a>
 </li>
+<li>pn_ssl_domain_set_protocols()
+: <a class="el" href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">ssl.h</a>
+</li>
 <li>pn_ssl_domain_set_trusted_ca_db()
 : <a class="el" href="group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d">ssl.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/globals_t.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/globals_t.html b/content/releases/qpid-proton-master/proton/c/api/globals_t.html
index 7d573f6..52f2f7a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/globals_t.html
+++ b/content/releases/qpid-proton-master/proton/c/api/globals_t.html
@@ -194,12 +194,12 @@ $(document).ready(function(){initNavTree('globals_t.html','');});
 <li>pn_tracker_t
 : <a class="el" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">messenger.h</a>
 </li>
-<li>pn_transport()
-: <a class="el" href="group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77">transport.h</a>
-</li>
 <li>PN_TRANSPORT
 : <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76">event.h</a>
 </li>
+<li>pn_transport()
+: <a class="el" href="group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77">transport.h</a>
+</li>
 <li>pn_transport_attachments()
 : <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864">transport.h</a>
 </li>
@@ -218,12 +218,12 @@ $(document).ready(function(){initNavTree('globals_t.html','');});
 <li>pn_transport_close_tail()
 : <a class="el" href="group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289">transport.h</a>
 </li>
-<li>pn_transport_closed()
-: <a class="el" href="group__transport.html#ga55c589d9b3e69057b130036c3c2173df">transport.h</a>
-</li>
 <li>PN_TRANSPORT_CLOSED
 : <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">event.h</a>
 </li>
+<li>pn_transport_closed()
+: <a class="el" href="group__transport.html#ga55c589d9b3e69057b130036c3c2173df">transport.h</a>
+</li>
 <li>pn_transport_condition()
 : <a class="el" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">transport.h</a>
 </li>
@@ -272,12 +272,12 @@ $(document).ready(function(){initNavTree('globals_t.html','');});
 <li>pn_transport_head()
 : <a class="el" href="group__transport.html#ga3ef8b0032b2a012c697e853e363338ea">transport.h</a>
 </li>
-<li>PN_TRANSPORT_HEAD_CLOSED
-: <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51">event.h</a>
-</li>
 <li>pn_transport_head_closed()
 : <a class="el" href="group__transport.html#ga3eb018b426d168de8c8d9b3441be036c">transport.h</a>
 </li>
+<li>PN_TRANSPORT_HEAD_CLOSED
+: <a class="el" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51">event.h</a>
+</li>
 <li>pn_transport_input()
 : <a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">transport.h</a>
 </li>
@@ -287,6 +287,9 @@ $(document).ready(function(){initNavTree('globals_t.html','');});
 <li>pn_transport_is_encrypted()
 : <a class="el" href="group__transport.html#ga737021ca419e948932071aad2ad38c5b">transport.h</a>
 </li>
+<li>pn_transport_local_addr()
+: <a class="el" href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">netaddr.h</a>
+</li>
 <li>pn_transport_log()
 : <a class="el" href="group__transport.html#gad603e8d72578bcedd2d9235f74f28f37">transport.h</a>
 </li>
@@ -317,6 +320,9 @@ $(document).ready(function(){initNavTree('globals_t.html','');});
 <li>PN_TRANSPORT_READ_CLOSED
 : <a class="el" href="group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb">connection_driver.h</a>
 </li>
+<li>pn_transport_remote_addr()
+: <a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">netaddr.h</a>
+</li>
 <li>pn_transport_remote_channel_max()
 : <a class="el" href="group__transport.html#gaff7c08aeb92596ad9d269468d1557647">transport.h</a>
 </li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__api__types.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__api__types.html b/content/releases/qpid-proton-master/proton/c/api/group__api__types.html
index aed1919..74afdc7 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__api__types.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__api__types.html
@@ -105,7 +105,7 @@ $(document).ready(function(){initNavTree('group__api__types.html','');});
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="nested-classes"></a>
 Classes</h2></td></tr>
 <tr class="memitem:structpn__atom__t"><td class="memItemLeft" align="right" valign="top">struct &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__api__types.html#structpn__atom__t">pn_atom_t</a></td></tr>
-<tr class="memdesc:structpn__atom__t"><td class="mdescLeft">&#160;</td><td class="mdescRight">A descriminated union that holds any scalar AMQP value.  <a href="group__api__types.html#structpn__atom__t">More...</a><br /></td></tr>
+<tr class="memdesc:structpn__atom__t"><td class="mdescLeft">&#160;</td><td class="mdescRight">A discriminated union that holds any scalar AMQP value.  <a href="group__api__types.html#structpn__atom__t">More...</a><br /></td></tr>
 <tr class="separator:structpn__atom__t"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:structpn__bytes__t"><td class="memItemLeft" align="right" valign="top">struct &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></td></tr>
 <tr class="memdesc:structpn__bytes__t"><td class="mdescLeft">&#160;</td><td class="mdescRight">A const byte buffer.  <a href="group__api__types.html#structpn__bytes__t">More...</a><br /></td></tr>
@@ -169,7 +169,7 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
-<div class="textblock"><p>A descriminated union that holds any scalar AMQP value. </p>
+<div class="textblock"><p>A discriminated union that holds any scalar AMQP value. </p>
 <p>The type field indicates the AMQP type of the value, and the union may be used to access the value for a given type. </p>
 </div><table class="fieldtable">
 <tr><th colspan="3">Class Members</th></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__connection.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__connection.html b/content/releases/qpid-proton-master/proton/c/api/group__connection.html
index fbe2777..1f1eebc 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__connection.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__connection.html
@@ -157,6 +157,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga7c88b4833cf81d801b27d00b45d137b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Release a connection object.  <a href="#ga7c88b4833cf81d801b27d00b45d137b5">More...</a><br /></td></tr>
 <tr class="separator:ga7c88b4833cf81d801b27d00b45d137b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad3aad758ccb4690e78d40c1a73567d73"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:gad3aad758ccb4690e78d40c1a73567d73"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="#gad3aad758ccb4690e78d40c1a73567d73">More...</a><br /></td></tr>
 <tr class="separator:gad3aad758ccb4690e78d40c1a73567d73"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2fd2089e8eaa2a362606498f233ada61"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">pn_connection_collect</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector)</td></tr>
 <tr class="memdesc:ga2fd2089e8eaa2a362606498f233ada61"><td class="mdescLeft">&#160;</td><td class="mdescRight">Associate a connection object with an event collector.  <a href="#ga2fd2089e8eaa2a362606498f233ada61">More...</a><br /></td></tr>
@@ -165,8 +166,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga663c29ee6de4d522ba061224bc6240ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the collector set with <a class="el" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61" title="Associate a connection object with an event collector. ">pn_connection_collect()</a>  <a href="#ga663c29ee6de4d522ba061224bc6240ad">More...</a><br /></td></tr>
 <tr class="separator:ga663c29ee6de4d522ba061224bc6240ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga50613e6c09186dc3f1a2f36238c61f07"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:ga50613e6c09186dc3f1a2f36238c61f07"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>.  <a href="#ga50613e6c09186dc3f1a2f36238c61f07">More...</a><br /></td></tr>
 <tr class="separator:ga50613e6c09186dc3f1a2f36238c61f07"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, void *context)</td></tr>
+<tr class="memdesc:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>.  <a href="#gad3203b366cb1ff5becd1778a8dd6b1a6">More...</a><br /></td></tr>
 <tr class="separator:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad8b6c777b525c9da9401e3a770db15da"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">pn_connection_attachments</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:gad8b6c777b525c9da9401e3a770db15da"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a connection object.  <a href="#gad8b6c777b525c9da9401e3a770db15da">More...</a><br /></td></tr>
@@ -226,10 +229,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:gac26de255ed04e73295d6aa973a663142"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access/modify the AMQP properties data for a connection object.  <a href="#gac26de255ed04e73295d6aa973a663142">More...</a><br /></td></tr>
 <tr class="separator:gac26de255ed04e73295d6aa973a663142"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga9bf90f0f395d26e320293063b70d040f"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
-<tr class="memdesc:ga9bf90f0f395d26e320293063b70d040f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP offered capabilites supplied by the remote connection endpoint.  <a href="#ga9bf90f0f395d26e320293063b70d040f">More...</a><br /></td></tr>
+<tr class="memdesc:ga9bf90f0f395d26e320293063b70d040f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP offered capabilities supplied by the remote connection endpoint.  <a href="#ga9bf90f0f395d26e320293063b70d040f">More...</a><br /></td></tr>
 <tr class="separator:ga9bf90f0f395d26e320293063b70d040f"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga722d53b6063278fbcab5f814613c70ec"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
-<tr class="memdesc:ga722d53b6063278fbcab5f814613c70ec"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP desired capabilites supplied by the remote connection endpoint.  <a href="#ga722d53b6063278fbcab5f814613c70ec">More...</a><br /></td></tr>
+<tr class="memdesc:ga722d53b6063278fbcab5f814613c70ec"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP desired capabilities supplied by the remote connection endpoint.  <a href="#ga722d53b6063278fbcab5f814613c70ec">More...</a><br /></td></tr>
 <tr class="separator:ga722d53b6063278fbcab5f814613c70ec"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga24a2d5aba432db549257993bfaa761dd"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">pn_connection_remote_properties</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:ga24a2d5aba432db549257993bfaa761dd"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP connection properties supplied by the remote connection endpoint.  <a href="#ga24a2d5aba432db549257993bfaa761dd">More...</a><br /></td></tr>
@@ -367,6 +370,8 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> </p>
 <p>Get additional error information associated with the connection.</p>
 <p>Whenever a connection operation fails (i.e. returns an error code), additional error details can be obtained using this function. The error object that is returned may also be used to clear the error condition.</p>
 <p>The pointer returned by this operation is valid until the connection object is freed.</p>
@@ -455,8 +460,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>. </p>
 <p>Get the application context that is associated with a connection object.</p>
-<p>The application context for a connection may be set using <a class="el" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a>.</p>
+<p>The application context for a connection may be set using <a class="el" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6" title="Deprecated - Use pn_connection_attachments(). ">pn_connection_set_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>the connection whose context is to be returned. </td></tr>
@@ -492,8 +499,10 @@ Functions</h2></td></tr>
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>. </p>
 <p>Set a new application context for a connection object.</p>
-<p>The application context for a connection object may be retrieved using <a class="el" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a>.</p>
+<p>The application context for a connection object may be retrieved using <a class="el" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07" title="Deprecated - Use pn_connection_attachments(). ">pn_connection_get_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>the connection object </td></tr>
@@ -789,8 +798,8 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Set the authentication username for a client connection. </p>
-<p>It is necessary to set the username and password before binding the connection to a trasnport and it isn't allowed to change them after the binding.</p>
-<p>If not set then no authentication will be negotiated unless the client sasl layer is explicitly created (this would be for sometting like Kerberos where the credentials are implicit in the environment, or to explicitly use the ANONYMOUS SASL mechanism)</p>
+<p>It is necessary to set the username and password before binding the connection to a transport and it isn't allowed to change them after the binding.</p>
+<p>If not set then no authentication will be negotiated unless the client sasl layer is explicitly created (this would be for something like Kerberos where the credentials are implicit in the environment, or to explicitly use the ANONYMOUS SASL mechanism)</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">connection</td><td>the connection </td></tr>
@@ -828,7 +837,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Set the authentication password for a client connection. </p>
-<p>It is necessary to set the username and password before binding the connection to a trasnport and it isn't allowed to change them after the binding.</p>
+<p>It is necessary to set the username and password before binding the connection to a transport and it isn't allowed to change them after the binding.</p>
 <p>Note that the password is write only and has no accessor as the underlying implementation should be zeroing the password after use to avoid the password being present in memory longer than necessary</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -1009,7 +1018,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Access/modify the AMQP offered capabilities data for a connection object. </p>
-<p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. Any data contained by the <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object will be sent as the offered capabilites for the parent connection object. Note that this MUST take the form of an array of symbols to be valid.</p>
+<p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. Any data contained by the <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object will be sent as the offered capabilities for the parent connection object. Note that this MUST take the form of an array of symbols to be valid.</p>
 <p>The <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> pointer returned is valid until the connection object is freed.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -1038,7 +1047,7 @@ Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Access/modify the AMQP desired capabilities data for a connection object. </p>
-<p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. Any data contained by the <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object will be sent as the desired capabilites for the parent connection object. Note that this MUST take the form of an array of symbols to be valid.</p>
+<p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. Any data contained by the <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object will be sent as the desired capabilities for the parent connection object. Note that this MUST take the form of an array of symbols to be valid.</p>
 <p>The <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> pointer returned is valid until the connection object is freed.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -1095,7 +1104,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Access the AMQP offered capabilites supplied by the remote connection endpoint. </p>
+<p>Access the AMQP offered capabilities supplied by the remote connection endpoint. </p>
 <p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. This data object will be empty until the remote connection is opened as indicated by the <a class="el" href="group__connection.html#gad96220f2886c21a4f2eebc9487f53a87" title="The remote endpoint state  is active. ">PN_REMOTE_ACTIVE</a> flag.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -1123,7 +1132,7 @@ Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Access the AMQP desired capabilites supplied by the remote connection endpoint. </p>
+<p>Access the AMQP desired capabilities supplied by the remote connection endpoint. </p>
 <p>This operation will return a pointer to a <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf" title="An AMQP Data object. ">pn_data_t</a> object that is valid until the connection object is freed. This data object will be empty until the remote connection is opened as indicated by the <a class="el" href="group__connection.html#gad96220f2886c21a4f2eebc9487f53a87" title="The remote endpoint state  is active. ">PN_REMOTE_ACTIVE</a> flag.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">


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


[12/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/connection__driver_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/connection__driver_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/connection__driver_8hpp_source.html
index a377559..a9dd619 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/connection__driver_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/connection__driver_8hpp_source.html
@@ -94,16 +94,16 @@ $(document).ready(function(){initNavTree('connection__driver_8hpp_source.html','
 </div><!--header-->
 <div class="contents">
 <a href="connection__driver_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_IO_CONNECTION_DRIVER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_IO_CONNECTION_DRIVER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="co
 mment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span cla
 ss="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or
  implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;../connection_options.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;../error_condition.hpp&quot;</span></div><div 
 class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;../fwd.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;../internal/config.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;../types_fwd.hpp&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;proton/connection_driver.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</
 span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">class </span>work_queue;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">class </span>proton_handler;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">namespace </span>io {</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno"><a class="line
 " href="structproton_1_1io_1_1mutable__buffer.html">   47</a></span>&#160;<span class="keyword">struct </span><a class="code" href="structproton_1_1io_1_1mutable__buffer.html">mutable_buffer</a> {</div><div class="line"><a name="l00048"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1mutable__buffer.html#a91a70b77df95bd8b0830b49a094c2acb">   48</a></span>&#160;    <span class="keywordtype">char</span>* <a class="code" href="structproton_1_1io_1_1mutable__buffer.html#a91a70b77df95bd8b0830b49a094c2acb">data</a>;                 </div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1mutable__buffer.html#a854352f53b148adc24983a58a1866d66">   49</a></span>&#160;    <span class="keywordtype">size_t</span> <a class="code" href="structproton_1_1io_1_1mutable__buffer.html#a854352f53b148adc24983a58a1866d66">size</a>;                </div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</d
 iv><div class="line"><a name="l00052"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1mutable__buffer.html#ae164359bc44e1b29a68ebc40555972c2">   52</a></span>&#160;    <a class="code" href="structproton_1_1io_1_1mutable__buffer.html#ae164359bc44e1b29a68ebc40555972c2">mutable_buffer</a>(<span class="keywordtype">char</span>* data_=0, <span class="keywordtype">size_t</span> size_=0) : data(data_), size(size_) {}</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;};</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1const__buffer.html">   57</a></span>&#160;<span class="keyword">struct </span><a class="code" href="structproton_1_1io_1_1const__buffer.html">const_buffer</a> {</div><div class="line"><a name="l00058"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1const__buffer
 .html#a8f64897c7ccc5c13f276d1d07c4e7095">   58</a></span>&#160;    <span class="keyword">const</span> <span class="keywordtype">char</span>* <a class="code" href="structproton_1_1io_1_1const__buffer.html#a8f64897c7ccc5c13f276d1d07c4e7095">data</a>;           </div><div class="line"><a name="l00059"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1const__buffer.html#a854352f53b148adc24983a58a1866d66">   59</a></span>&#160;    <span class="keywordtype">size_t</span> <a class="code" href="structproton_1_1io_1_1const__buffer.html#a854352f53b148adc24983a58a1866d66">size</a>;                </div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno"><a class="line" href="structproton_1_1io_1_1const__buffer.html#a91a09264a182ec89354136e9b2c51fe4">   62</a></span>&#160;    <a class="code" href="structproton_1_1io_1_1const__buffer.html#a91a09264a182ec89354136e9b2c51fe4">const_buffer<
 /a>(<span class="keyword">const</span> <span class="keywordtype">char</span>* data_=0, <span class="keywordtype">size_t</span> size_=0) : data(data_), size(size_) {}</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;};</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno"><a class="line" href="classproton_1_1io_1_1connection__driver.html">   93</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1io_1_1connection__driver.html">connection_driver</a> {</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1io_1_1connection
 __driver.html">connection_driver</a>();</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN connection_driver(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    PN_CPP_EXTERN ~connection_driver();</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    <span class="keywordtype">void</span> configure(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; opts=<a class="code" href="classproton_1_1connection__options.html">connection_options</a>(), <span class="keywordtype">bool</span> server=<span cla
 ss="keyword">false</span>);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> connect(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; opts);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> accept(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp; opts);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;    PN_CPP_EXTERN <a class="code" href="structproton_1_1io_1_1mutable__buff
 er.html">mutable_buffer</a> read_buffer();</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> read_done(<span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> read_close();</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;    PN_CPP_EXTERN <a class="code" href="structproton_1_1io_1_1const__buffer.html">const_buffer</a> write_buffer();</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</sp
 an>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> write_done(<span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> write_close();</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1timestamp.html">timestamp</a> tick(<a class="code" href="classproton_1_1timestamp.html">timestamp</a> now);</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> disconnected(<span class="keyword">const</span> <a class="code" href="classproton_1_1e
 rror__condition.html">error_condition</a>&amp; = <a class="code" href="classproton_1_1error__condition.html">error_condition</a>());</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> has_events() <span class="keyword">const</span>;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> dispatch();</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection.html">proton::connection</a> <a class="code" href="classproton_1_1connection.html">connection</a>() <span class="keyword">co
 nst</span>;</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1transport.html">proton::transport</a> <a class="code" href="classproton_1_1transport.html">transport</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1container.html">proton::container</a>* <a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160; <span class="keyword">private</span>:</div><div class="line"><a name="l00196"></a><spa
 n class="lineno">  196</span>&#160;    <span class="keywordtype">void</span> init();</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;    connection_driver(<span class="keyword">const</span> connection_driver&amp;);</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;    connection_driver&amp; operator=(<span class="keyword">const</span> connection_driver&amp;);</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;    std::string container_id_;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;    <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>* handler_;</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;    pn_connection_driver_t driver_;</div><div class="line"><a name="l00203"></a><span class="lineno">  2
 03</span>&#160;};</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;} <span class="comment">// io</span></div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;<span class="preprocessor">#endif // PROTON_IO_CONNECTION_DRIVER_HPP</span></div><div class="ttc" id="structproton_1_1io_1_1const__buffer_html_a854352f53b148adc24983a58a1866d66"><div class="ttname"><a href="structproton_1_1io_1_1const__buffer.html#a854352f53b148adc24983a58a1866d66">proton::io::const_buffer::size</a></div><div class="ttdeci">size_t size</div><div class="ttdoc">Number of bytes in the buffer. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:59</div>
 </div>
-<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="structproton_1_1io_1_1const__buffer_html"><div class="ttname"><a href="structproton_1_1io_1_1const__buffer.html">proton::io::const_buffer</a></div><div class="ttdoc">Unsettled API - A pointer to an immutable memory region with a size. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:57</div></div>
 <div class="ttc" id="classproton_1_1connection_html"><div class="ttname"><a href="classproton_1_1connection.html">proton::connection</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div><div class="ttdef"><b>Definition:</b> connection.hpp:43</div></div>
-<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:65</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:66</div></div>
 <div class="ttc" id="structproton_1_1io_1_1mutable__buffer_html_ae164359bc44e1b29a68ebc40555972c2"><div class="ttname"><a href="structproton_1_1io_1_1mutable__buffer.html#ae164359bc44e1b29a68ebc40555972c2">proton::io::mutable_buffer::mutable_buffer</a></div><div class="ttdeci">mutable_buffer(char *data_=0, size_t size_=0)</div><div class="ttdoc">Construct a buffer starting at data_ with size_ bytes. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:52</div></div>
 <div class="ttc" id="structproton_1_1io_1_1const__buffer_html_a8f64897c7ccc5c13f276d1d07c4e7095"><div class="ttname"><a href="structproton_1_1io_1_1const__buffer.html#a8f64897c7ccc5c13f276d1d07c4e7095">proton::io::const_buffer::data</a></div><div class="ttdeci">const char * data</div><div class="ttdoc">Beginning of the buffered data. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:58</div></div>
 <div class="ttc" id="structproton_1_1io_1_1mutable__buffer_html_a91a70b77df95bd8b0830b49a094c2acb"><div class="ttname"><a href="structproton_1_1io_1_1mutable__buffer.html#a91a70b77df95bd8b0830b49a094c2acb">proton::io::mutable_buffer::data</a></div><div class="ttdeci">char * data</div><div class="ttdoc">Beginning of the buffered data. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:48</div></div>
 <div class="ttc" id="classproton_1_1timestamp_html"><div class="ttname"><a href="classproton_1_1timestamp.html">proton::timestamp</a></div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> timestamp.hpp:35</div></div>
 <div class="ttc" id="structproton_1_1io_1_1mutable__buffer_html_a854352f53b148adc24983a58a1866d66"><div class="ttname"><a href="structproton_1_1io_1_1mutable__buffer.html#a854352f53b148adc24983a58a1866d66">proton::io::mutable_buffer::size</a></div><div class="ttdeci">size_t size</div><div class="ttdoc">Number of bytes in the buffer. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:49</div></div>
-<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:61</div></div>
+<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:62</div></div>
 <div class="ttc" id="structproton_1_1io_1_1const__buffer_html_a91a09264a182ec89354136e9b2c51fe4"><div class="ttname"><a href="structproton_1_1io_1_1const__buffer.html#a91a09264a182ec89354136e9b2c51fe4">proton::io::const_buffer::const_buffer</a></div><div class="ttdeci">const_buffer(const char *data_=0, size_t size_=0)</div><div class="ttdoc">Construct a buffer starting at data_ with size_ bytes. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:62</div></div>
 <div class="ttc" id="classproton_1_1transport_html"><div class="ttname"><a href="classproton_1_1transport.html">proton::transport</a></div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> transport.hpp:37</div></div>
 <div class="ttc" id="structproton_1_1io_1_1mutable__buffer_html"><div class="ttname"><a href="structproton_1_1io_1_1mutable__buffer.html">proton::io::mutable_buffer</a></div><div class="ttdoc">Unsettled API - A pointer to a mutable memory region with a size. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:47</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/connection__options_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/connection__options_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/connection__options_8hpp_source.html
index 63d8b6a..4842283 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/connection__options_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/connection__options_8hpp_source.html
@@ -93,8 +93,8 @@ $(document).ready(function(){initNavTree('connection__options_8hpp_source.html',
 <div class="title">connection_options.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="connection__options_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_OPTIONS_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_OPTIONS_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment">
  * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lin
 eno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implie
 d.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="duration_8hpp.html">./duration.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" hr
 ef="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line">
 <a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">struct </span>pn_connection_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</di
 v><div class="line"><a name="l00065"></a><span class="lineno"><a class="line" href="classproton_1_1connection__options.html">   65</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1connection__options.html">connection_options</a> {</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>();</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>(<span class="keyword">class</span> <a class="code" href="classproton_1_1mess
 aging__handler.html">messaging_handler</a>&amp; h);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>(<span class="keyword">const</span> connection_options&amp;);</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN ~connection_options();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">operator=</a>(<span class="keyword">const</span> connection_optio
 ns&amp;);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    <span class="comment">// XXX add C++11 move operations - Still relevant, and applies to all options</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">handler</a>(<span class="keyword">class</span> <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp;);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options
 .html#ad0e93961fd048b2ee5e8bdac2b041686">max_frame_size</a>(uint32_t max);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#af66706fdb4a2f3f4d9943be9ee4b1347">max_sessions</a>(uint16_t max);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a7c838237bfba8a5a04c2b97e6f023448">idle_timeout</a>(<a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    PN_CPP_EXTERN connectio
 n_options&amp; <a class="code" href="classproton_1_1connection__options.html#a4c6429303ccb719d9c585c88f300e007">container_id</a>(<span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a0300a2a68ecca3f684e91e637a45e028">virtual_host</a>(<span class="keyword">const</span> std::string&amp; name);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a10afa48d580025f71f0a6dd31bd1de24">user</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a n
 ame="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a78a90a1387cf91915dbe39b888955d75">password</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a4eb280b5a62adb5b2075d6316a590c70">ssl_client_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1ssl__client__options.html">ssl_client_options</a>&amp;);</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</sp
 an>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a5ce3c4591be545f5ae67f22ef64fb9ef">ssl_server_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1ssl__server__options.html">ssl_server_options</a>&amp;);</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#aedcd8a70f24d08ab0bb6178524ae6a0d">sasl_enabled</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#afbabea03db40dee25da7bbdc7e9
 18322">sasl_allow_insecure_mechs</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a52f0724b86920647ef8624922aa54ab6">sasl_allowed_mechs</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#ad8e93a44cab5e65949046fb036c237a6">sasl_config_name</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00151"></a><span class="lineno">  151</
 span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a0fc40d55673b5c89e4b5a13c630edca5">sasl_config_path</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">reconnect</a>(<a class="code" href="classproton_1_1reconnect__options.html">reconnect_options</a> &amp;);</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a68a8c198dfa16653afc4a70a2b845604">update</a>(<span class="keyword">const</span> connecti
 on_options&amp; other);</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;    <span class="keywordtype">void</span> apply_unbound(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;) <span class="keyword">const</span>;</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;    <span class="keywordtype">void</span> apply_bound(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;) <span class="keyword">const</span>;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;    <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>* handler() <span class="keyword">const</span>;</div><div class="line"><a name="l00163"></a><span 
 class="lineno">  163</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    <span class="keyword">class </span>impl;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;    internal::pn_unique_ptr&lt;impl&gt; impl_;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>;</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1io_1_1connection__driver.html">io::connection_driver</a>;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;  <span class="keyword">friend</span> <span class="keyword">cla
 ss </span><a class="code" href="classproton_1_1connection.html">connection</a>;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;};</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;<span class="preprocessor">#endif // PROTON_CONNECTION_OPTIONS_H</span></div><div class="ttc" id="classproton_1_1ssl__server__options_html"><div class="ttname"><a href="classproton_1_1ssl__server__options.html">proton::ssl_server_options</a></div><div class="ttdoc">Unsettled API - SSL configuration for inbound connections. </div><div class="ttdef"><b>Definition:</b> ssl.hpp:148</div></div>
-<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<a href="connection__options_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_OPTIONS_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_OPTIONS_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment">
  * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lin
 eno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implie
 d.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="duration_8hpp.html">./duration.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" hr
 ef="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line">
 <a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">struct </span>pn_connection_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">struct </span>pn_transport_t;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">namespace </span><a class=
 "code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno"><a class="line" href="classproton_1_1connection__options.html">   66</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1connection__options.html">connection_options</a> {</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>();</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html
 #a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>(<span class="keyword">class</span> <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp; h);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>(<span class="keyword">const</span> connection_options&amp;);</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;    PN_CPP_EXTERN ~connection_options();</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="class
 proton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">operator=</a>(<span class="keyword">const</span> connection_options&amp;);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    <span class="comment">// XXX add C++11 move operations - Still relevant, and applies to all options</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">handler</a>(<span class="keyword">class</span> <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>&amp;);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00091"></a><s
 pan class="lineno">   91</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#ad0e93961fd048b2ee5e8bdac2b041686">max_frame_size</a>(uint32_t max);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#af66706fdb4a2f3f4d9943be9ee4b1347">max_sessions</a>(uint16_t max);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a7c838237bfba8a5a04c2b97e6f023448">idle_timeout</a>(<a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00103"></a><span class="li
 neno">  103</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a4c6429303ccb719d9c585c88f300e007">container_id</a>(<span class="keyword">const</span> std::string&amp; <span class="keywordtype">id</span>);</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a0300a2a68ecca3f684e91e637a45e028">virtual_host</a>(<span class="keyword">const</span> std::string&amp; name);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__opt
 ions.html#a10afa48d580025f71f0a6dd31bd1de24">user</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a78a90a1387cf91915dbe39b888955d75">password</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a4eb280b5a62adb5b2075d6316a590c70">ssl_client_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1ssl__client__options.html">ssl_client_options</a>&amp;);</div><div class="line">
 <a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a5ce3c4591be545f5ae67f22ef64fb9ef">ssl_server_options</a>(<span class="keyword">const</span> <span class="keyword">class</span> <a class="code" href="classproton_1_1ssl__server__options.html">ssl_server_options</a>&amp;);</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#aedcd8a70f24d08ab0bb6178524ae6a0d">sasl_enabled</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#1
 60;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#afbabea03db40dee25da7bbdc7e918322">sasl_allow_insecure_mechs</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a52f0724b86920647ef8624922aa54ab6">sasl_allowed_mechs</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#ad8e93a44cab5e65949046fb036c237a6">sasl_config_name</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line
 "><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#a0fc40d55673b5c89e4b5a13c630edca5">sasl_config_path</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;    PN_CPP_EXTERN connection_options&amp; <a class="code" href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">reconnect</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1reconnect__options.html">reconnect_options</a> &amp;);</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;    PN_CPP_EXTERN conne
 ction_options&amp; <a class="code" href="classproton_1_1connection__options.html#a68a8c198dfa16653afc4a70a2b845604">update</a>(<span class="keyword">const</span> connection_options&amp; other);</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;    <span class="keywordtype">void</span> apply_unbound(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;) <span class="keyword">const</span>;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;    <span class="keywordtype">void</span> apply_unbound_client(pn_transport_t*) <span class="keyword">const</span>;</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;    <span class="keywordtype">void</span> apply_unbound_server(p
 n_transport_t*) <span class="keyword">const</span>;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>* handler() <span class="keyword">const</span>;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;    <span class="keyword">class </span>impl;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;    internal::pn_unique_ptr&lt;impl&gt; impl_;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>
 &#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1io_1_1connection__driver.html">io::connection_driver</a>;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1connection.html">connection</a>;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;};</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;<span class="preprocessor">#endif // PROTON_CONNECTION_OPTIONS_H</span></div><div class="ttc" id="classproton_1_1ssl__server__options_ht
 ml"><div class="ttname"><a href="classproton_1_1ssl__server__options.html">proton::ssl_server_options</a></div><div class="ttdoc">Unsettled API - SSL configuration for inbound connections. </div><div class="ttdef"><b>Definition:</b> ssl.hpp:149</div></div>
+<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1reconnect__options_html"><div class="ttname"><a href="classproton_1_1reconnect__options.html">proton::reconnect_options</a></div><div class="ttdoc">Unsettled API - Options for reconnect and failover after connection loss. </div><div class="ttdef"><b>Definition:</b> reconnect_options.hpp:49</div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_af66706fdb4a2f3f4d9943be9ee4b1347"><div class="ttname"><a href="classproton_1_1connection__options.html#af66706fdb4a2f3f4d9943be9ee4b1347">proton::connection_options::max_sessions</a></div><div class="ttdeci">connection_options &amp; max_sessions(uint16_t max)</div><div class="ttdoc">Set the maximum number of open sessions. The default is 32767. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a68a8c198dfa16653afc4a70a2b845604"><div class="ttname"><a href="classproton_1_1connection__options.html#a68a8c198dfa16653afc4a70a2b845604">proton::connection_options::update</a></div><div class="ttdeci">connection_options &amp; update(const connection_options &amp;other)</div><div class="ttdoc">Update option values from values set in other. </div></div>
@@ -102,13 +102,12 @@ $(document).ready(function(){initNavTree('connection__options_8hpp_source.html',
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a52f0724b86920647ef8624922aa54ab6"><div class="ttname"><a href="classproton_1_1connection__options.html#a52f0724b86920647ef8624922aa54ab6">proton::connection_options::sasl_allowed_mechs</a></div><div class="ttdeci">connection_options &amp; sasl_allowed_mechs(const std::string &amp;)</div><div class="ttdoc">Specify the allowed mechanisms for use on the connection. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a0fc40d55673b5c89e4b5a13c630edca5"><div class="ttname"><a href="classproton_1_1connection__options.html#a0fc40d55673b5c89e4b5a13c630edca5">proton::connection_options::sasl_config_path</a></div><div class="ttdeci">connection_options &amp; sasl_config_path(const std::string &amp;)</div><div class="ttdoc">Unsettled API - Set the SASL configuration path. </div></div>
-<div class="ttc" id="classproton_1_1connection__options_html_a5a38fafc56619c03e10979b978393bbc"><div class="ttname"><a href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">proton::connection_options::reconnect</a></div><div class="ttdeci">connection_options &amp; reconnect(reconnect_options &amp;)</div><div class="ttdoc">Unsettled API - Set reconnect and failover options. </div></div>
 <div class="ttc" id="classproton_1_1connection_html"><div class="ttname"><a href="classproton_1_1connection.html">proton::connection</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div><div class="ttdef"><b>Definition:</b> connection.hpp:43</div></div>
-<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:65</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:66</div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a8034b8d17ca30a4cfc3db8c6a898dc4d"><div class="ttname"><a href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">proton::connection_options::connection_options</a></div><div class="ttdeci">connection_options()</div><div class="ttdoc">Create an empty set of options. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a5ce3c4591be545f5ae67f22ef64fb9ef"><div class="ttname"><a href="classproton_1_1connection__options.html#a5ce3c4591be545f5ae67f22ef64fb9ef">proton::connection_options::ssl_server_options</a></div><div class="ttdeci">connection_options &amp; ssl_server_options(const class ssl_server_options &amp;)</div><div class="ttdoc">Set SSL server options. </div></div>
 <div class="ttc" id="duration_8hpp_html"><div class="ttname"><a href="duration_8hpp.html">duration.hpp</a></div><div class="ttdoc">A span of time in milliseconds. </div></div>
-<div class="ttc" id="classproton_1_1ssl__client__options_html"><div class="ttname"><a href="classproton_1_1ssl__client__options.html">proton::ssl_client_options</a></div><div class="ttdoc">Unsettled API - SSL configuration for outbound connections. </div><div class="ttdef"><b>Definition:</b> ssl.hpp:175</div></div>
+<div class="ttc" id="classproton_1_1ssl__client__options_html"><div class="ttname"><a href="classproton_1_1ssl__client__options.html">proton::ssl_client_options</a></div><div class="ttdoc">Unsettled API - SSL configuration for outbound connections. </div><div class="ttdef"><b>Definition:</b> ssl.hpp:176</div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a7bca23aeb3455378ef2d35975758e504"><div class="ttname"><a href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">proton::connection_options::handler</a></div><div class="ttdeci">connection_options &amp; handler(class messaging_handler &amp;)</div><div class="ttdoc">Set a connection handler. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_aedcd8a70f24d08ab0bb6178524ae6a0d"><div class="ttname"><a href="classproton_1_1connection__options.html#aedcd8a70f24d08ab0bb6178524ae6a0d">proton::connection_options::sasl_enabled</a></div><div class="ttdeci">connection_options &amp; sasl_enabled(bool)</div><div class="ttdoc">Enable or disable SASL. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a4eb280b5a62adb5b2075d6316a590c70"><div class="ttname"><a href="classproton_1_1connection__options.html#a4eb280b5a62adb5b2075d6316a590c70">proton::connection_options::ssl_client_options</a></div><div class="ttdeci">connection_options &amp; ssl_client_options(const class ssl_client_options &amp;)</div><div class="ttdoc">Set SSL client options. </div></div>
@@ -118,7 +117,8 @@ $(document).ready(function(){initNavTree('connection__options_8hpp_source.html',
 <div class="ttc" id="classproton_1_1connection__options_html_a78a90a1387cf91915dbe39b888955d75"><div class="ttname"><a href="classproton_1_1connection__options.html#a78a90a1387cf91915dbe39b888955d75">proton::connection_options::password</a></div><div class="ttdeci">connection_options &amp; password(const std::string &amp;)</div><div class="ttdoc">Set the password used to authenticate the connection. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a10afa48d580025f71f0a6dd31bd1de24"><div class="ttname"><a href="classproton_1_1connection__options.html#a10afa48d580025f71f0a6dd31bd1de24">proton::connection_options::user</a></div><div class="ttdeci">connection_options &amp; user(const std::string &amp;)</div><div class="ttdoc">Set the user name used to authenticate the connection. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a2c612e142b60cf61ce50d88582465167"><div class="ttname"><a href="classproton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">proton::connection_options::operator=</a></div><div class="ttdeci">connection_options &amp; operator=(const connection_options &amp;)</div><div class="ttdoc">Copy options. </div></div>
-<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:61</div></div>
+<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:62</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html_ad053f0ac823eefd100731c1b5248e7e8"><div class="ttname"><a href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">proton::connection_options::reconnect</a></div><div class="ttdeci">connection_options &amp; reconnect(const reconnect_options &amp;)</div><div class="ttdoc">Unsettled API - Set reconnect and failover options. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_ad0e93961fd048b2ee5e8bdac2b041686"><div class="ttname"><a href="classproton_1_1connection__options.html#ad0e93961fd048b2ee5e8bdac2b041686">proton::connection_options::max_frame_size</a></div><div class="ttdeci">connection_options &amp; max_frame_size(uint32_t max)</div><div class="ttdoc">Set the maximum frame size. It is unlimited by default. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a0300a2a68ecca3f684e91e637a45e028"><div class="ttname"><a href="classproton_1_1connection__options.html#a0300a2a68ecca3f684e91e637a45e028">proton::connection_options::virtual_host</a></div><div class="ttdeci">connection_options &amp; virtual_host(const std::string &amp;name)</div><div class="ttdoc">Set the virtual host name for the connection. </div></div>
 <div class="ttc" id="classproton_1_1connection__options_html_a4c6429303ccb719d9c585c88f300e007"><div class="ttname"><a href="classproton_1_1connection__options.html#a4c6429303ccb719d9c585c88f300e007">proton::connection_options::container_id</a></div><div class="ttdeci">connection_options &amp; container_id(const std::string &amp;id)</div><div class="ttdoc">Set the container ID. </div></div>


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


[19/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classes.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classes.html b/content/releases/qpid-proton-master/proton/cpp/api/classes.html
index ef6af7f..548dfd7 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classes.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classes.html
@@ -93,43 +93,45 @@ $(document).ready(function(){initNavTree('classes.html','');});
 <div class="title">Class Index</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="qindex"><a class="qindex" href="#letter_a">a</a>&#160;|&#160;<a class="qindex" href="#letter_b">b</a>&#160;|&#160;<a class="qindex" href="#letter_c">c</a>&#160;|&#160;<a class="qindex" href="#letter_d">d</a>&#160;|&#160;<a class="qindex" href="#letter_e">e</a>&#160;|&#160;<a class="qindex" href="#letter_f">f</a>&#160;|&#160;<a class="qindex" href="#letter_l">l</a>&#160;|&#160;<a class="qindex" href="#letter_m">m</a>&#160;|&#160;<a class="qindex" href="#letter_r">r</a>&#160;|&#160;<a class="qindex" href="#letter_s">s</a>&#160;|&#160;<a class="qindex" href="#letter_t">t</a>&#160;|&#160;<a class="qindex" href="#letter_u">u</a>&#160;|&#160;<a class="qindex" href="#letter_v">v</a>&#160;|&#160;<a class="qindex" href="#letter_w">w</a></div>
+<div class="qindex"><a class="qindex" href="#letter_a">a</a>&#160;|&#160;<a class="qindex" href="#letter_b">b</a>&#160;|&#160;<a class="qindex" href="#letter_c">c</a>&#160;|&#160;<a class="qindex" href="#letter_d">d</a>&#160;|&#160;<a class="qindex" href="#letter_e">e</a>&#160;|&#160;<a class="qindex" href="#letter_f">f</a>&#160;|&#160;<a class="qindex" href="#letter_l">l</a>&#160;|&#160;<a class="qindex" href="#letter_m">m</a>&#160;|&#160;<a class="qindex" href="#letter_n">n</a>&#160;|&#160;<a class="qindex" href="#letter_r">r</a>&#160;|&#160;<a class="qindex" href="#letter_s">s</a>&#160;|&#160;<a class="qindex" href="#letter_t">t</a>&#160;|&#160;<a class="qindex" href="#letter_u">u</a>&#160;|&#160;<a class="qindex" href="#letter_v">v</a>&#160;|&#160;<a class="qindex" href="#letter_w">w</a></div>
 <table class="classindex">
 <tr><td rowspan="2" valign="bottom"><a name="letter_a"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;a&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1decimal32.html">decimal32</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1scalar.html">scalar</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1terminus.html">terminus</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1decimal64.html">decimal64</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1listener.html">listener</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1scalar__base.html">scalar_base</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1timeout__error.html">timeout_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1annotation__key.html">annotation_key</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1codec_1_1decoder.html">decoder</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_m"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;m&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1sender.html">sender</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1timestamp.html">timestamp</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+</td><td valign="top"><a class="el" href="classproton_1_1decimal64.html">decimal64</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_m"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;m&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1scalar.html">scalar</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1timeout__error.html">timeout_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1codec_1_1decoder.html">decoder</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1scalar__base.html">scalar_base</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1timestamp.html">timestamp</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1annotation__key.html">annotation_key</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1delivery.html">delivery</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1map.html">map</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1sender.html">sender</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1tracker.html">tracker</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
 <tr><td rowspan="2" valign="bottom"><a name="letter_b"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;b&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1delivery.html">delivery</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1sender__options.html">sender_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1tracker.html">tracker</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="structproton_1_1delivery__mode.html">delivery_mode</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1map.html">map</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1session.html">session</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1transfer.html">transfer</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1binary.html">binary</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1duration.html">duration</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1message.html">message</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1session__options.html">session_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1transport.html">transport</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1byte__array.html">byte_array</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_e"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;e&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1message__id.html">message_id</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1source.html">source</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_u"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;u&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="structproton_1_1delivery__mode.html">delivery_mode</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1message.html">message</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1sender__options.html">sender_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1transfer.html">transfer</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1duration.html">duration</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1message__id.html">message_id</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1session.html">session</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1transport.html">transport</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1binary.html">binary</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_e"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;e&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1session__options.html">session_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_u"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;u&#160;&#160;</div></td></tr></table>
 </td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1byte__array.html">byte_array</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1io_1_1mutable__buffer.html">mutable_buffer</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1source.html">source</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
 <tr><td rowspan="2" valign="bottom"><a name="letter_c"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;c&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1source__options.html">source_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1io_1_1mutable__buffer.html">mutable_buffer</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1ssl.html">ssl</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1url.html">url</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1connection.html">connection</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1endpoint.html">endpoint</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_r"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;r&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1ssl__certificate.html">ssl_certificate</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1url__error.html">url_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1io_1_1connection__driver.html">connection_driver</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1error.html">error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1ssl__client__options.html">ssl_client_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1uuid.html">uuid</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1connection__options.html">connection_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1error__condition.html">error_condition</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1receiver.html">receiver</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1ssl__server__options.html">ssl_server_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_v"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;v&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_n"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;n&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1source__options.html">source_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1url.html">url</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1endpoint.html">endpoint</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1ssl.html">ssl</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1url__error.html">url_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1connection.html">connection</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="structproton_1_1error.html">error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1null.html">null</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1ssl__certificate.html">ssl_certificate</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1uuid.html">uuid</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1io_1_1connection__driver.html">connection_driver</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1error__condition.html">error_condition</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_r"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;r&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1ssl__client__options.html">ssl_client_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_v"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;v&#160;&#160;</div></td></tr></table>
 </td></tr>
-<tr><td valign="top"><a class="el" href="structproton_1_1io_1_1const__buffer.html">const_buffer</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_f"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;f&#160;&#160;</div></td></tr></table>
-</td><td valign="top"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1container.html">container</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1reconnect__options.html">reconnect_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1symbol.html">symbol</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1value.html">value</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="structproton_1_1conversion__error.html">conversion_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1returned.html">returned</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_t"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;t&#160;&#160;</div></td></tr></table>
-</td><td rowspan="2" valign="bottom"><a name="letter_w"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;w&#160;&#160;</div></td></tr></table>
+<tr><td valign="top"><a class="el" href="classproton_1_1connection__options.html">connection_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_f"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;f&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1ssl__server__options.html">ssl_server_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="structproton_1_1io_1_1const__buffer.html">const_buffer</a> (<a class="el" href="namespaceproton_1_1io.html">proton::io</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1receiver.html">receiver</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1value.html">value</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1container.html">container</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a> (<a class="el" href="namespaceproton_1_1codec.html">proton::codec</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1symbol.html">symbol</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_w"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;w&#160;&#160;</div></td></tr></table>
 </td></tr>
-<tr><td rowspan="2" valign="bottom"><a name="letter_d"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;d&#160;&#160;</div></td></tr></table>
-</td><td rowspan="2" valign="bottom"><a name="letter_l"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;l&#160;&#160;</div></td></tr></table>
-</td><td rowspan="2" valign="bottom"><a name="letter_s"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;s&#160;&#160;</div></td></tr></table>
+<tr><td valign="top"><a class="el" href="structproton_1_1conversion__error.html">conversion_error</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_l"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;l&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1reconnect__options.html">reconnect_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_t"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;t&#160;&#160;</div></td></tr></table>
 </td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1target.html">target</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1work.html">work</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
-<tr><td valign="top"><a class="el" href="classproton_1_1decimal128.html">decimal128</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1link.html">link</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1sasl.html">sasl</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1target__options.html">target_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1work__queue.html">work_queue</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td rowspan="2" valign="bottom"><a name="letter_d"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;d&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1returned.html">returned</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1work__queue.html">work_queue</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1link.html">link</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td rowspan="2" valign="bottom"><a name="letter_s"></a><table border="0" cellspacing="0" cellpadding="0"><tr><td><div class="ah">&#160;&#160;s&#160;&#160;</div></td></tr></table>
+</td><td valign="top"><a class="el" href="classproton_1_1target.html">target</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td></td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1decimal128.html">decimal128</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1target__options.html">target_options</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td></td></tr>
+<tr><td valign="top"><a class="el" href="classproton_1_1decimal32.html">decimal32</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1listener.html">listener</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1sasl.html">sasl</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td valign="top"><a class="el" href="classproton_1_1terminus.html">terminus</a> (<a class="el" href="namespaceproton.html">proton</a>)&#160;&#160;&#160;</td><td></td></tr>
 <tr><td></td><td></td><td></td><td></td><td></td></tr>
 </table>
-<div class="qindex"><a class="qindex" href="#letter_a">a</a>&#160;|&#160;<a class="qindex" href="#letter_b">b</a>&#160;|&#160;<a class="qindex" href="#letter_c">c</a>&#160;|&#160;<a class="qindex" href="#letter_d">d</a>&#160;|&#160;<a class="qindex" href="#letter_e">e</a>&#160;|&#160;<a class="qindex" href="#letter_f">f</a>&#160;|&#160;<a class="qindex" href="#letter_l">l</a>&#160;|&#160;<a class="qindex" href="#letter_m">m</a>&#160;|&#160;<a class="qindex" href="#letter_r">r</a>&#160;|&#160;<a class="qindex" href="#letter_s">s</a>&#160;|&#160;<a class="qindex" href="#letter_t">t</a>&#160;|&#160;<a class="qindex" href="#letter_u">u</a>&#160;|&#160;<a class="qindex" href="#letter_v">v</a>&#160;|&#160;<a class="qindex" href="#letter_w">w</a></div>
+<div class="qindex"><a class="qindex" href="#letter_a">a</a>&#160;|&#160;<a class="qindex" href="#letter_b">b</a>&#160;|&#160;<a class="qindex" href="#letter_c">c</a>&#160;|&#160;<a class="qindex" href="#letter_d">d</a>&#160;|&#160;<a class="qindex" href="#letter_e">e</a>&#160;|&#160;<a class="qindex" href="#letter_f">f</a>&#160;|&#160;<a class="qindex" href="#letter_l">l</a>&#160;|&#160;<a class="qindex" href="#letter_m">m</a>&#160;|&#160;<a class="qindex" href="#letter_n">n</a>&#160;|&#160;<a class="qindex" href="#letter_r">r</a>&#160;|&#160;<a class="qindex" href="#letter_s">s</a>&#160;|&#160;<a class="qindex" href="#letter_t">t</a>&#160;|&#160;<a class="qindex" href="#letter_u">u</a>&#160;|&#160;<a class="qindex" href="#letter_v">v</a>&#160;|&#160;<a class="qindex" href="#letter_w">w</a></div>
 </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1decoder.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1decoder.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1decoder.html
index cc8f22c..39771c8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1decoder.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1decoder.html
@@ -226,7 +226,7 @@ template&lt;class T &gt; </td></tr>
 <a class="el" href="classproton_1_1codec_1_1decoder.html">decoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&gt;&gt;</b> (internal::value_base &amp;)</td></tr>
 <tr class="separator:a93c5ccb222d57853fd0f97f2b6cbdf62"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:affae6ad78f8a4884bcb1a37e2119f00a"><td class="memItemLeft" align="right" valign="top"><a id="affae6ad78f8a4884bcb1a37e2119f00a"></a>
-<a class="el" href="classproton_1_1codec_1_1decoder.html">decoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&gt;&gt;</b> (null &amp;)</td></tr>
+<a class="el" href="classproton_1_1codec_1_1decoder.html">decoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&gt;&gt;</b> (<a class="el" href="classproton_1_1null.html">null</a> &amp;)</td></tr>
 <tr class="separator:affae6ad78f8a4884bcb1a37e2119f00a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="friends"></a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder-members.html
index 736bdbe..4617a70 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder-members.html
@@ -123,9 +123,10 @@ $(document).ready(function(){initNavTree('classproton_1_1codec_1_1encoder.html',
   <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>operator&lt;&lt;</b>(const binary &amp;) (defined in <a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a>)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
   <tr bgcolor="#f0f0f0"><td class="entry"><b>operator&lt;&lt;</b>(const scalar_base &amp;) (defined in <a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a>)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
   <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>operator&lt;&lt;</b>(const null &amp;) (defined in <a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a>)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#a041e90045de495b728fb95bbed97a531">operator&lt;&lt;</a>(const internal::value_base &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#ae899d62164114228541da27e80372bc2">operator&lt;&lt;</a>(const start &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#a4ffe2e23e17b2c241074e52944916e8a">operator&lt;&lt;</a>(const finish &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>operator&lt;&lt;</b>(decltype(nullptr)) (defined in <a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a>)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#a041e90045de495b728fb95bbed97a531">operator&lt;&lt;</a>(const internal::value_base &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#ae899d62164114228541da27e80372bc2">operator&lt;&lt;</a>(const start &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html#a4ffe2e23e17b2c241074e52944916e8a">operator&lt;&lt;</a>(const finish &amp;)</td><td class="entry"><a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.html
index de0995a..49a1dba 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.html
@@ -200,8 +200,11 @@ Public Member Functions</h2></td></tr>
 <a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&lt;&lt;</b> (const <a class="el" href="classproton_1_1scalar__base.html">scalar_base</a> &amp;)</td></tr>
 <tr class="separator:a79c97aab9f563c515301adb35951b752"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a1a22fc8bfea6eee79c2af6e1c66f8f59"><td class="memItemLeft" align="right" valign="top"><a id="a1a22fc8bfea6eee79c2af6e1c66f8f59"></a>
-<a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&lt;&lt;</b> (const null &amp;)</td></tr>
+<a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&lt;&lt;</b> (const <a class="el" href="classproton_1_1null.html">null</a> &amp;)</td></tr>
 <tr class="separator:a1a22fc8bfea6eee79c2af6e1c66f8f59"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a37c5cab14118fbcf7e37fb35e4e09246"><td class="memItemLeft" align="right" valign="top"><a id="a37c5cab14118fbcf7e37fb35e4e09246"></a>
+<a class="el" href="classproton_1_1codec_1_1encoder.html">encoder</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator&lt;&lt;</b> (decltype(nullptr))</td></tr>
+<tr class="separator:a37c5cab14118fbcf7e37fb35e4e09246"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p><b>Unsettled API</b> - A stream-like encoder from C++ values to AMQP bytes. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.js
index 59cf80c..136fb05 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1codec_1_1encoder.js
@@ -27,6 +27,7 @@ var classproton_1_1codec_1_1encoder =
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#a2d41565e7410ec7a72097da5b399fd79", null ],
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#a79c97aab9f563c515301adb35951b752", null ],
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#a1a22fc8bfea6eee79c2af6e1c66f8f59", null ],
+    [ "operator<<", "classproton_1_1codec_1_1encoder.html#a37c5cab14118fbcf7e37fb35e4e09246", null ],
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#a041e90045de495b728fb95bbed97a531", null ],
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#ae899d62164114228541da27e80372bc2", null ],
     [ "operator<<", "classproton_1_1codec_1_1encoder.html#a4ffe2e23e17b2c241074e52944916e8a", null ]

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection.html
index 6a8c7ec..00bf8fb 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection.html
@@ -223,7 +223,7 @@ sender_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A connection to a remote AMQP peer. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a19">broker.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a6">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a12">multithreaded_client.cpp</a>, <a class="el" href="server_8cpp-example.html#_a2">server.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a11">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a17">broker.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a5">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a12">multithreaded_client.cpp</a>, <a class="el" href="server_8cpp-example.html#_a1">server.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a12">service_bus.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a2f632b80247e868b8264b8a025b84baf"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a2f632b80247e868b8264b8a025b84baf">&#9670;&nbsp;</a></span>container()</h2>
@@ -247,7 +247,8 @@ sender_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
   </table>
   </dd>
 </dl>
-
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a25">broker.cpp</a>.</dd>
+</dl>
 </div>
 </div>
 <a id="a9e8555112049fc2b4945120b3c45f8ab"></a>
@@ -267,7 +268,8 @@ sender_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 
 <p>Open the connection. </p>
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
-
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a18">broker.cpp</a>.</dd>
+</dl>
 </div>
 </div>
 <a id="a91b014b59b8b14d7f5a26e2e4950cc93"></a>
@@ -318,7 +320,7 @@ sender_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
 
 <p>Implements <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>.</p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a20">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a13">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a15">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a19">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a18">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a7">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a9">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a14">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a12">scheduled_send_03.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a22">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a16">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.
 html#a17">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a20">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a13">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a14">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a17">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a7">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a9">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a14">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a12">scheduled_send_03.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a25">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a16">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a17">simple_send.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -565,14 +567,12 @@ sender_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 </div><div class="memdoc">
 
 <p><b>Unsettled API</b> - Trigger an event from another thread. </p>
-<p><code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">wake()</a></code> can be called from any thread. The Proton library will call <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - an event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> as soon as possible in the correct event-handling thread.</p>
-<dl class="section note"><dt>Note</dt><dd></dd></dl>
-<ul>
-<li>Thread-safe: This is the <em>only</em> <a class="el" href="classproton_1_1connection.html">connection</a> function that can be called from outside the handler thread.</li>
-<li>Multiple calls to <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">wake()</a></code> may be coalesced into a single call to <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - an event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> that occurs after all of them.</li>
-<li>Spurious <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - an event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> calls can occur even if the application does not call <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">wake()</a></code>.</li>
-</ul>
-<p>The <a class="el" href="classproton_1_1work__queue.html">work_queue</a> interface provides an easier way execute code safely in the event-handler thread. </p>
+<p>This method can be called from any thread. The Proton library will call <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - An event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> as soon as possible in the correct event-handling thread.</p>
+<p><b>Thread-safety</b> - This is the <em>only</em> <code><a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a></code> function that can be called from outside the handler thread.</p>
+<dl class="section note"><dt>Note</dt><dd>Spurious <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - An event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> calls can occur even if the application does not call <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">wake()</a></code>.</dd>
+<dd>
+Multiple calls to <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">wake()</a></code> may be coalesced into a single call to <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - An event that can be triggered from another thread. ">messaging_handler::on_connection_wake()</a></code> that occurs after all of them.</dd></dl>
+<p>The <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> interface provides an easier way execute code safely in the event-handler thread. </p>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options-members.html
index b0f16b2..503a7fc 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options-members.html
@@ -106,7 +106,7 @@ $(document).ready(function(){initNavTree('classproton_1_1connection__options.htm
   <tr><td class="entry"><a class="el" href="classproton_1_1connection__options.html#af66706fdb4a2f3f4d9943be9ee4b1347">max_sessions</a>(uint16_t max)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">operator=</a>(const connection_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1connection__options.html#a78a90a1387cf91915dbe39b888955d75">password</a>(const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">reconnect</a>(reconnect_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">reconnect</a>(const reconnect_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1connection__options.html#afbabea03db40dee25da7bbdc7e918322">sasl_allow_insecure_mechs</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1connection__options.html#a52f0724b86920647ef8624922aa54ab6">sasl_allowed_mechs</a>(const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1connection__options.html#ad8e93a44cab5e65949046fb036c237a6">sasl_config_name</a>(const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1connection__options.html">connection_options</a></td><td class="entry"></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.html
index 67a9424..c3ca74d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.html
@@ -174,10 +174,10 @@ Public Member Functions</h2></td></tr>
 <a class="el" href="classproton_1_1connection__options.html">connection_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1connection__options.html#a0fc40d55673b5c89e4b5a13c630edca5">sasl_config_path</a> (const std::string &amp;)</td></tr>
 <tr class="memdesc:a0fc40d55673b5c89e4b5a13c630edca5"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Set the SASL configuration path. <br /></td></tr>
 <tr class="separator:a0fc40d55673b5c89e4b5a13c630edca5"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a5a38fafc56619c03e10979b978393bbc"><td class="memItemLeft" align="right" valign="top"><a id="a5a38fafc56619c03e10979b978393bbc"></a>
-<a class="el" href="classproton_1_1connection__options.html">connection_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">reconnect</a> (<a class="el" href="classproton_1_1reconnect__options.html">reconnect_options</a> &amp;)</td></tr>
-<tr class="memdesc:a5a38fafc56619c03e10979b978393bbc"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Set reconnect and failover options. <br /></td></tr>
-<tr class="separator:a5a38fafc56619c03e10979b978393bbc"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ad053f0ac823eefd100731c1b5248e7e8"><td class="memItemLeft" align="right" valign="top"><a id="ad053f0ac823eefd100731c1b5248e7e8"></a>
+<a class="el" href="classproton_1_1connection__options.html">connection_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">reconnect</a> (const <a class="el" href="classproton_1_1reconnect__options.html">reconnect_options</a> &amp;)</td></tr>
+<tr class="memdesc:ad053f0ac823eefd100731c1b5248e7e8"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Set reconnect and failover options. <br /></td></tr>
+<tr class="separator:ad053f0ac823eefd100731c1b5248e7e8"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a68a8c198dfa16653afc4a70a2b845604"><td class="memItemLeft" align="right" valign="top"><a id="a68a8c198dfa16653afc4a70a2b845604"></a>
 <a class="el" href="classproton_1_1connection__options.html">connection_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1connection__options.html#a68a8c198dfa16653afc4a70a2b845604">update</a> (const <a class="el" href="classproton_1_1connection__options.html">connection_options</a> &amp;other)</td></tr>
 <tr class="memdesc:a68a8c198dfa16653afc4a70a2b845604"><td class="mdescLeft">&#160;</td><td class="mdescRight">Update option values from values set in other. <br /></td></tr>
@@ -188,7 +188,7 @@ Public Member Functions</h2></td></tr>
 <p>Options can be "chained" like this:</p>
 <div class="fragment"><div class="line">c = container.connect(url, <a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>().<a class="code" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">handler</a>(h).<a class="code" href="classproton_1_1connection__options.html#ad0e93961fd048b2ee5e8bdac2b041686">max_frame_size</a>(1234));</div></div><!-- fragment --><p>You can also create an options object with common settings and use it as a base for different connections that have mostly the same settings:</p>
 <div class="fragment"><div class="line"><a class="code" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a> opts;</div><div class="line">opts.idle_timeout(1000).max_frame_size(10000);</div><div class="line">c1 = container.connect(url1, opts.handler(h1));</div><div class="line">c2 = container.connect(url2, opts.handler(h2));</div></div><!-- fragment --><p>Normal value semantics: copy or assign creates a separate copy of the options. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a29">broker.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a5">multithreaded_client_flow_control.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a1">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a4">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a4">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a35">broker.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a5">multithreaded_client_flow_control.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a1">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a4">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a4">simple_send.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a7bca23aeb3455378ef2d35975758e504"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a7bca23aeb3455378ef2d35975758e504">&#9670;&nbsp;</a></span>handler()</h2>
@@ -207,8 +207,8 @@ Public Member Functions</h2></td></tr>
 </div><div class="memdoc">
 
 <p>Set a connection handler. </p>
-<p>The handler must not be deleted until <a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f" title="The underlying network transport has closed. ">messaging_handler::on_transport_close()</a> is called. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a31">broker.cpp</a>.</dd>
+<p>The handler must not be deleted until <a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f" title="The underlying network transport has closed. ">messaging_handler::on_transport_close()</a> is called. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a37">broker.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.js
index b0baeb7..96af388 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1connection__options.js
@@ -20,6 +20,6 @@ var classproton_1_1connection__options =
     [ "sasl_allowed_mechs", "classproton_1_1connection__options.html#a52f0724b86920647ef8624922aa54ab6", null ],
     [ "sasl_config_name", "classproton_1_1connection__options.html#ad8e93a44cab5e65949046fb036c237a6", null ],
     [ "sasl_config_path", "classproton_1_1connection__options.html#a0fc40d55673b5c89e4b5a13c630edca5", null ],
-    [ "reconnect", "classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc", null ],
+    [ "reconnect", "classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8", null ],
     [ "update", "classproton_1_1connection__options.html#a68a8c198dfa16653afc4a70a2b845604", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container-members.html
index f3e5d44..5ef0ea2 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container-members.html
@@ -101,8 +101,10 @@ $(document).ready(function(){initNavTree('classproton_1_1container.html','');});
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a8d0986a84403bdf62da9649c5de123d3">client_connection_options</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1">connect</a>(const std::string &amp;conn_url, const connection_options &amp;conn_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a422bf1e05b6a01039f0ef603b2f165a4">connect</a>(const std::string &amp;conn_url)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a822ca363beceb76ffdc5ce370a4f9356">container</a>(messaging_handler &amp;handler, const std::string &amp;id=&quot;&quot;)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#aa73c3a48d397b513182a2d90ba5ab686">container</a>(const std::string &amp;id=&quot;&quot;)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a9a322df81c8d397bb4c3fa6c1a67a496">container</a>(messaging_handler &amp;handler, const std::string &amp;id)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a3d7f4be6b8ace086ed7470f66a742059">container</a>(messaging_handler &amp;handler)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a88125a4442a7b28fab97a89587627c0f">container</a>(const std::string &amp;id)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#aeacc0140de439ebab9a5466c45d38191">container</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677">id</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>(const std::string &amp;listen_url, listen_handler &amp;handler)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1container.html#ae234654c72fe7b272728028cd88b8c1c">listen</a>(const std::string &amp;listen_url, const connection_options &amp;conn_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
@@ -120,13 +122,14 @@ $(document).ready(function(){initNavTree('classproton_1_1container.html','');});
   <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#ac48e94529e54c7e7342fde28b26d9f48">run</a>(int count)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26">schedule</a>(duration dur, work fn)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a4fb43ab767dd944cfea2cc169f112488">sender_options</a>(const class sender_options &amp;snd_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#ae7bfc8d811be7f6be17be6cf15e35b4a">sender_options</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a7daf70330e5259fbb6ae3f01cfbc125a">server_connection_options</a>(const connection_options &amp;conn_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a0e7a536b46ab843775da5390754c9bf6">server_connection_options</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#ade42a19caab198f0fd1d28e03cf9ba0e">stop</a>(const error_condition &amp;err)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a8c528baf37154d347366083f0f816846">stop</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a7c64e64cedfa36303be53f0f581d1d24">~container</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a3e20a15733ef55ac0c43fbe1e60813d4">schedule</a>(duration dur, void_function0 &amp;fn)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a4fb43ab767dd944cfea2cc169f112488">sender_options</a>(const class sender_options &amp;snd_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#ae7bfc8d811be7f6be17be6cf15e35b4a">sender_options</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a7daf70330e5259fbb6ae3f01cfbc125a">server_connection_options</a>(const connection_options &amp;conn_opts)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a0e7a536b46ab843775da5390754c9bf6">server_connection_options</a>() const</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#ade42a19caab198f0fd1d28e03cf9ba0e">stop</a>(const error_condition &amp;err)</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1container.html#a8c528baf37154d347366083f0f816846">stop</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1container.html#a7c64e64cedfa36303be53f0f581d1d24">~container</a>()</td><td class="entry"><a class="el" href="classproton_1_1container.html">container</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->


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


[29/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/reactor_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/reactor_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/reactor_8h_source.html
index aca38db..f727b98 100755
--- a/content/releases/qpid-proton-master/proton/c/api/reactor_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/reactor_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/reactor.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,16 +93,16 @@ $(document).ready(function(){initNavTree('reactor_8h_source.html','');});
 <div class="title">reactor.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_REACTOR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_REACTOR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name
 ="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><s
 pan class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno"> 
   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class
 ="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/selectable.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="ssl_8h.html">proton/ssl.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="l
 ine"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_reactor_t pn_reactor_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_acceptor_t pn_acceptor_t;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_timer_t pn_timer_t;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_task_t pn_task_t;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;
 </div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;PNX_EXTERN pn_handler_t *pn_handler(<span class="keywordtype">void</span> (*dispatch)(pn_handler_t *, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *, <a class="code" href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a>));</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;PNX_EXTERN pn_handler_t *pn_handler_new(<span class="keywordtype">void</span> (*dispatch)(pn_handler_t *, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *, <a class="code" href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a>), <span class="keywordtype">size_t</span> size,</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;                                       <span class="keywordtype">void</span> (*finalize)(pn_handler_t *));</
 div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_free(pn_handler_t *handler);</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> *pn_handler_mem(pn_handler_t *handler);</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_add(pn_handler_t *handler, pn_handler_t *child);</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_clear(pn_handler_t *handler);</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_dispatch(pn_handler_t *handler, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event, <a class="code"
  href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a> type);</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;PNX_EXTERN pn_reactor_t *pn_reactor(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PNX_EXTERN pn_record_t *pn_reactor_attachments(pn_reactor_t *reactor);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;PNX_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> pn_reactor_get_timeout(pn_reactor_t *reactor);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_timeout(pn_reactor_t *reactor, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>
  timeout);</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_reactor_mark(pn_reactor_t *reactor);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_reactor_now(pn_reactor_t *reactor);</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_yield(pn_reactor_t *reactor);</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_free(pn_reactor_t *reactor);</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;PNX_EXTERN <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn
 _collector_t</a> *pn_reactor_collector(pn_reactor_t *reactor);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;PNX_EXTERN pn_handler_t *pn_reactor_get_global_handler(pn_reactor_t *reactor);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_global_handler(pn_reactor_t *reactor, pn_handler_t *handler);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;PNX_EXTERN pn_handler_t *pn_reactor_get_handler(pn_reactor_t *reactor);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_handler(pn_reactor_t *reactor, pn_handler_t *handler);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PNX_EXTERN pn_list_t *pn_reactor_children(pn_reactor_t *reactor);</div><div class="line"><a name="l00068"></a><span class="
 lineno">   68</span>&#160;PNX_EXTERN pn_selectable_t *pn_reactor_selectable(pn_reactor_t *reactor);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_update(pn_reactor_t *reactor, pn_selectable_t *selectable);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PNX_EXTERN pn_acceptor_t *pn_reactor_acceptor(pn_reactor_t *reactor, <span class="keyword">const</span> <span class="keywordtype">char</span> *host, <span class="keyword">const</span> <span class="keywordtype">char</span> *port,</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;                                             pn_handler_t *handler);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PNX_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *pn_reactor_error(pn_reactor_t *reactor);</di
 v><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;PNX_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *pn_reactor_connection_to_host(pn_reactor_t *reactor,</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;                                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *host,</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;                                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *port,</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;                                                         pn_handler_t *handler);</div><div class="line"><a name="l00091"></a><span class="lineno
 ">   91</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PNX_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *pn_reactor_connection(pn_reactor_t *reactor,</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;                                                 pn_handler_t *handler);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_connection_host(pn_reactor_t *reactor,</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;                                              <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection,</div><div class="line"><a name="l00122"></a><span class="lineno"> 
  122</span>&#160;                                              <span class="keyword">const</span> <span class="keywordtype">char</span> *host,</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;                                              <span class="keyword">const</span> <span class="keywordtype">char</span> *port);</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_reactor_get_connection_address(pn_reactor_t *reactor,</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;                                                        <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#16
 0;PNX_EXTERN <span class="keywordtype">int</span> pn_reactor_wakeup(pn_reactor_t *reactor);</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_start(pn_reactor_t *reactor);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_reactor_quiesced(pn_reactor_t *reactor);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_reactor_process(pn_reactor_t *reactor);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_stop(pn_reactor_t *reactor);</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_run(pn_reactor_t *reactor);</div><div class="line"><a name="l00152
 "></a><span class="lineno">  152</span>&#160;PNX_EXTERN pn_task_t *pn_reactor_schedule(pn_reactor_t *reactor, <span class="keywordtype">int</span> delay, pn_handler_t *handler);</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_acceptor_set_ssl_domain(pn_acceptor_t *acceptor, <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_acceptor_close(pn_acceptor_t *acceptor);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;PNX_EXTERN pn_acceptor_t *pn_connection_acceptor(<a class="code" href="group__connection.html#ga886351d8
 1ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;PNX_EXTERN pn_timer_t *pn_timer(<a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_timer_deadline(pn_timer_t *timer);</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_timer_tick(pn_timer_t *timer, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> now);</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;PNX_EXTERN pn_task_t *pn_timer_schedule(pn
 _timer_t *timer, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> deadline);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> pn_timer_tasks(pn_timer_t *timer);</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;PNX_EXTERN pn_record_t *pn_task_attachments(pn_task_t *task);</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_task_cancel(pn_task_t *task);</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;PNX_EXTERN pn_reactor_t *pn_class_reactor(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span 
 class="keywordtype">object</span>);</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;PNX_EXTERN pn_reactor_t *pn_object_reactor(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;PNX_EXTERN pn_reactor_t *pn_event_reactor(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;PNX_EXTERN pn_handler_t *pn_record_get_handler(pn_record_t *record);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_record_set_handler(pn_record_t *record, pn_handler_t *handler);</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;</div><div 
 class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;PNX_EXTERN pn_handler_t *pn_event_root(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;}</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* reactor.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c
 3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:139</div></div>
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_REACTOR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_REACTOR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name
 ="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><s
 pan class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno"> 
   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class
 ="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/selectable.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="ssl_8h.html">proton/ssl.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="l
 ine"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_reactor_t pn_reactor_t;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_acceptor_t pn_acceptor_t;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_timer_t pn_timer_t;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_task_t pn_task_t;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;
 </div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;PNX_EXTERN pn_handler_t *pn_handler(<span class="keywordtype">void</span> (*dispatch)(pn_handler_t *, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *, <a class="code" href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a>));</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;PNX_EXTERN pn_handler_t *pn_handler_new(<span class="keywordtype">void</span> (*dispatch)(pn_handler_t *, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *, <a class="code" href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a>), <span class="keywordtype">size_t</span> size,</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;                                       <span class="keywordtype">void</span> (*finalize)(pn_handler_t *));</
 div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_free(pn_handler_t *handler);</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> *pn_handler_mem(pn_handler_t *handler);</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_add(pn_handler_t *handler, pn_handler_t *child);</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_clear(pn_handler_t *handler);</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_handler_dispatch(pn_handler_t *handler, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event, <a class="code"
  href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a> type);</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;PNX_EXTERN pn_reactor_t *pn_reactor(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PNX_EXTERN pn_record_t *pn_reactor_attachments(pn_reactor_t *reactor);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;PNX_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> pn_reactor_get_timeout(pn_reactor_t *reactor);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_timeout(pn_reactor_t *reactor, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>
  timeout);</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_reactor_mark(pn_reactor_t *reactor);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_reactor_now(pn_reactor_t *reactor);</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_yield(pn_reactor_t *reactor);</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_free(pn_reactor_t *reactor);</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;PNX_EXTERN <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn
 _collector_t</a> *pn_reactor_collector(pn_reactor_t *reactor);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;PNX_EXTERN pn_handler_t *pn_reactor_get_global_handler(pn_reactor_t *reactor);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_global_handler(pn_reactor_t *reactor, pn_handler_t *handler);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;PNX_EXTERN pn_handler_t *pn_reactor_get_handler(pn_reactor_t *reactor);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_handler(pn_reactor_t *reactor, pn_handler_t *handler);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PNX_EXTERN pn_list_t *pn_reactor_children(pn_reactor_t *reactor);</div><div class="line"><a name="l00068"></a><span class="
 lineno">   68</span>&#160;PNX_EXTERN pn_selectable_t *pn_reactor_selectable(pn_reactor_t *reactor);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_update(pn_reactor_t *reactor, pn_selectable_t *selectable);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PNX_EXTERN pn_acceptor_t *pn_reactor_acceptor(pn_reactor_t *reactor, <span class="keyword">const</span> <span class="keywordtype">char</span> *host, <span class="keyword">const</span> <span class="keywordtype">char</span> *port,</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;                                             pn_handler_t *handler);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PNX_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *pn_reactor_error(pn_reactor_t *reactor);</di
 v><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;PNX_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *pn_reactor_connection_to_host(pn_reactor_t *reactor,</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;                                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *host,</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;                                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *port,</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;                                                         pn_handler_t *handler);</div><div class="line"><a name="l00091"></a><span class="lineno
 ">   91</span>&#160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;PNX_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *pn_reactor_connection(pn_reactor_t *reactor,</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;                                                 pn_handler_t *handler);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_set_connection_host(pn_reactor_t *reactor,</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;                                              <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection,</div><div class="line"><a name="l00123"></a><span class="lineno"> 
  123</span>&#160;                                              <span class="keyword">const</span> <span class="keywordtype">char</span> *host,</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;                                              <span class="keyword">const</span> <span class="keywordtype">char</span> *port);</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_reactor_get_connection_address(pn_reactor_t *reactor,</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;                                                        <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#16
 0;PNX_EXTERN <span class="keywordtype">int</span> pn_reactor_wakeup(pn_reactor_t *reactor);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_start(pn_reactor_t *reactor);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_reactor_quiesced(pn_reactor_t *reactor);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_reactor_process(pn_reactor_t *reactor);</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_stop(pn_reactor_t *reactor);</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_reactor_run(pn_reactor_t *reactor);</div><div class="line"><a name="l00153
 "></a><span class="lineno">  153</span>&#160;PNX_EXTERN pn_task_t *pn_reactor_schedule(pn_reactor_t *reactor, <span class="keywordtype">int</span> delay, pn_handler_t *handler);</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_acceptor_set_ssl_domain(pn_acceptor_t *acceptor, <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_acceptor_close(pn_acceptor_t *acceptor);</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;PNX_EXTERN pn_acceptor_t *pn_connection_acceptor(<a class="code" href="group__connection.html#ga886351d8
 1ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;PNX_EXTERN pn_timer_t *pn_timer(<a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_timer_deadline(pn_timer_t *timer);</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_timer_tick(pn_timer_t *timer, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> now);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;PNX_EXTERN pn_task_t *pn_timer_schedule(pn
 _timer_t *timer, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> deadline);</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> pn_timer_tasks(pn_timer_t *timer);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;PNX_EXTERN pn_record_t *pn_task_attachments(pn_task_t *task);</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_task_cancel(pn_task_t *task);</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;PNX_EXTERN pn_reactor_t *pn_class_reactor(<span class="keyword">const</span> pn_class_t *clazz, <span class="keywordtype">void</span> *<span 
 class="keywordtype">object</span>);</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;PNX_EXTERN pn_reactor_t *pn_object_reactor(<span class="keywordtype">void</span> *<span class="keywordtype">object</span>);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;PNX_EXTERN pn_reactor_t *pn_event_reactor(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;PNX_EXTERN pn_handler_t *pn_record_get_handler(pn_record_t *record);</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_record_set_handler(pn_record_t *record, pn_handler_t *handler);</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div 
 class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;PNX_EXTERN pn_handler_t *pn_event_root(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;}</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* reactor.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c
 3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:145</div></div>
 <div class="ttc" id="group__event_html_ga4876e2eed24a4d4e4c52b99842103cda"><div class="ttname"><a href="group__event.html#ga4876e2eed24a4d4e4c52b99842103cda">pn_event_type_t</a></div><div class="ttdeci">pn_event_type_t</div><div class="ttdoc">An event type. </div><div class="ttdef"><b>Definition:</b> event.h:80</div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
-<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:407</div></div>
+<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
 <div class="ttc" id="error_8h_html"><div class="ttname"><a href="error_8h.html">error.h</a></div><div class="ttdoc">A Proton API error. </div></div>
 <div class="ttc" id="group__ssl_html_gaba83c3a1779c8b35a479bf3a7bb5b175"><div class="ttname"><a href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a></div><div class="ttdeci">struct pn_ssl_domain_t pn_ssl_domain_t</div><div class="ttdoc">API for using SSL with the Transport Layer. </div><div class="ttdef"><b>Definition:</b> ssl.h:80</div></div>
 <div class="ttc" id="event_8h_html"><div class="ttname"><a href="event_8h.html">event.h</a></div><div class="ttdoc">Protocol and transport events. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:275</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="ssl_8h_html"><div class="ttname"><a href="ssl_8h.html">ssl.h</a></div><div class="ttdoc">SSL secure transport layer. </div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:160</div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 <div class="ttc" id="group__event_html_ga87f3028b4888632bbd56fb71ac737ae8"><div class="ttname"><a href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a></div><div class="ttdeci">struct pn_event_t pn_event_t</div><div class="ttdoc">Notification of a state change in the protocol engine. </div><div class="ttdef"><b>Definition:</b> event.h:75</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
@@ -112,7 +112,7 @@ $(document).ready(function(){initNavTree('reactor_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>reactor.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/receive_8c-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/receive_8c-example.html b/content/releases/qpid-proton-master/proton/c/api/receive_8c-example.html
index 166f875..f546d7c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/receive_8c-example.html
+++ b/content/releases/qpid-proton-master/proton/c/api/receive_8c-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('receive_8c-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>Subscribes to the 'example' node and prints the message bodies received.Can be used with <a class="el" href="broker_8c-example.html">broker.c</a>, <a class="el" href="direct_8c-example.html">direct.c</a> or an external AMQP broker.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8h.html">proton/connection.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8h.html">proton/delivery.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8h.html">proton/message.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="proactor_8h.html">proton/proactor.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="session_8h.html">proton/session.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;
 </span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;stdio.h&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;stdlib.h&gt;</span></div><div class="line"></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>app_data_t {</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *host, *port;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *amqp_address;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *container_id;</div><div class="line">  <span class="keywordtype">int</span> message_count;</div><div class="line"></div><div class="line">  <a class="code" href="types_8h.html#abba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor;</div><div class="line">  <span class="keywordtype">int</span> received;</div><div class="line">  <span 
 class="keywordtype">bool</span> finished;</div><div class="line">} app_data_t;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keyword">const</span> <span class="keywordtype">int</span> BATCH = 1000; <span class="comment">/* Batch size for unlimited receive */</span></div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">int</span> exit_code = 0;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> check_condition(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *cond) {</div><div class="line">  <span class="keywordflow">if</span> (<a name="a0"></a><a class="code" href="group__condition.html#ga112611a7a4087e050c476a430db2cfb9">pn_condition_is_set</a>(cond)) {</div><div clas
 s="line">    fprintf(stderr, <span class="stringliteral">&quot;%s: %s: %s\n&quot;</span>, <a name="a1"></a><a class="code" href="group__event.html#ga3a85c046c11ce692c23b9566b022d54b">pn_event_type_name</a>(<a name="a2"></a><a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(e)),</div><div class="line">            <a name="a3"></a><a class="code" href="group__condition.html#ga05b0d374d90f11d9ebbf818662569689">pn_condition_get_name</a>(cond), <a name="a4"></a><a class="code" href="group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8">pn_condition_get_description</a>(cond));</div><div class="line">    <a name="a5"></a><a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a name="a6"></a><a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e));</div><div class="line">    exit_code = 1;</div><div class="line">  }</div><div class="line">}</div><d
 iv class="line"></div><div class="line"><span class="preprocessor">#define MAX_SIZE 1024</span></div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> decode_message(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *dlv) {</div><div class="line">  <span class="keyword">static</span> <span class="keywordtype">char</span> buffer[MAX_SIZE];</div><div class="line">  ssize_t len;</div><div class="line">  <span class="comment">// try to decode the message body</span></div><div class="line">  <span class="keywordflow">if</span> (<a name="a7"></a><a class="code" href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a>(dlv) &lt; MAX_SIZE) {</div><div class="line">    <span class="comment">// read in the raw data</span></div><div class="line">    len = <a name="a8"></a><a class="code" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_
 recv</a>(<a name="a9"></a><a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(dlv), buffer, MAX_SIZE);</div><div class="line">    <span class="keywordflow">if</span> (len &gt; 0) {</div><div class="line">      <span class="comment">// decode it into a proton message</span></div><div class="line">      <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *m = <a name="a10"></a><a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>();</div><div class="line">      <span class="keywordflow">if</span> (<a name="a11"></a><a class="code" href="group__error.html#gac73fbd2363c5f562f85dde459e631394">PN_OK</a> == <a name="a12"></a><a class="code" href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">pn_message_decode</a>(m, buffer, len)) {</div><div class="line">        pn_string_t *s = pn_string(NULL);</div><div class="line">        pn_inspect(<a name="a13"><
 /a><a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(m), s);</div><div class="line">        printf(<span class="stringliteral">&quot;%s\n&quot;</span>, pn_string_get(s));</div><div class="line">        pn_free(s);</div><div class="line">      }</div><div class="line">      <a name="a14"></a><a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(m);</div><div class="line">    }</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Return true to continue, false to exit */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">bool</span> handle(app_data_t* app, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* event) {</div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__event.html#gacaea54ca51885933b4987c1
 31a3d1b0d">pn_event_type</a>(event)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a15"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e">PN_CONNECTION_INIT</a>: {</div><div class="line">     <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>* c = <a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event);</div><div class="line">     <a name="a16"></a><a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(c, app-&gt;container_id);</div><div class="line">     <a name="a17"></a><a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(c);</div><div class="line">     <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a>* s = <a name
 ="a18"></a><a class="code" href="group__session.html#ga1feff407b8fe308a14f283d193246f3c">pn_session</a>(c);</div><div class="line">     <a name="a19"></a><a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(s);</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>* l = <a name="a20"></a><a class="code" href="group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f">pn_receiver</a>(s, <span class="stringliteral">&quot;my_receiver&quot;</span>);</div><div class="line">     <a name="a21"></a><a class="code" href="group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1">pn_terminus_set_address</a>(<a name="a22"></a><a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(l), app-&gt;amqp_address);</div><div class="line">     <a name="a23"></a><a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(l);</div><div cl
 ass="line">     <span class="comment">/* cannot receive without granting credit: */</span></div><div class="line">     <a name="a24"></a><a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(l, app-&gt;message_count ? app-&gt;message_count : BATCH);</div><div class="line">   } <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a25"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a>: {</div><div class="line">     <span class="comment">/* A message has been received */</span></div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link = NULL;</div><div class="line">     <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *dlv = <a name="a26"></a><a class="code" href="group__event
 .html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a>(event);</div><div class="line">     <span class="keywordflow">if</span> (<a name="a27"></a><a class="code" href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a>(dlv) &amp;&amp; !<a name="a28"></a><a class="code" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a>(dlv)) {</div><div class="line">       link = <a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(dlv);</div><div class="line">       decode_message(dlv);</div><div class="line">       <span class="comment">/* Accept the delivery */</span></div><div class="line">       <a name="a29"></a><a class="code" href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a>(dlv, <a name="a30"></a><a class="code" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">PN_ACCEPTED</a>);</div><div class="line">       <span class="
 comment">/* done with the delivery, move to the next and free it */</span></div><div class="line">       <a name="a31"></a><a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(link);</div><div class="line">       <a name="a32"></a><a class="code" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(dlv);  <span class="comment">/* dlv is now freed */</span></div><div class="line"></div><div class="line">       <span class="keywordflow">if</span> (app-&gt;message_count == 0) {</div><div class="line">         <span class="comment">/* receive forever - see if more credit is needed */</span></div><div class="line">         <span class="keywordflow">if</span> (<a name="a33"></a><a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(link) &lt; BATCH/2) {</div><div class="line">           <span class="comment">/* Grant enough credit to bring it up to BATCH: */</span></div><div c
 lass="line">           <a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(link, BATCH - <a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(link));</div><div class="line">         }</div><div class="line">       } <span class="keywordflow">else</span> <span class="keywordflow">if</span> (++app-&gt;received &gt;= app-&gt;message_count) {</div><div class="line">         <span class="comment">/* done receiving, close the endpoints */</span></div><div class="line">         printf(<span class="stringliteral">&quot;%d messages received\n&quot;</span>, app-&gt;received);</div><div class="line">         <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *ssn = <a name="a34"></a><a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(link);</div><div class="line">         <a name="a35"></a><a class="code" href="group__link.html#
 ga4851693eb6a16fd9ab61e2df6f00770d">pn_link_close</a>(link);</div><div class="line">         <a name="a36"></a><a class="code" href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a>(ssn);</div><div class="line">         <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a name="a37"></a><a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(ssn));</div><div class="line">       }</div><div class="line">     }</div><div class="line">   } <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a38"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a>:</div><div class="line">    check_condition(event, <a name="a39"></a><a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c
 34">pn_transport_condition</a>(<a name="a40"></a><a class="code" href="group__event.html#ga14525ae84870388141898bbf57f2b151">pn_event_transport</a>(event)));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a41"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f">PN_CONNECTION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a42"></a><a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a
 >(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a43"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135">PN_SESSION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(event, <a name="a44"></a><a class="code" href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remote_condition</a>(<a name="a45"></a><a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="
 keywordflow">case</span> <a name="a46"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f">PN_LINK_REMOTE_CLOSE</a>:</div><div class="line">   <span class="keywordflow">case</span> <a name="a47"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2">PN_LINK_REMOTE_DETACH</a>:</div><div class="line">    check_condition(event, <a name="a48"></a><a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a name="a49"></a><a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(event)));</div><div class="line">    <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(event));</div><div class="line">    <span class="keywordflow">break</span
 >;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a50"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a>:</div><div class="line">    <span class="keywordflow">return</span> <span class="keyword">false</span>;</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</span>:</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line">  }</div><div class="line">    <span class="keywordflow">return</span> <span class="keyword">true</span>;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> run(app_data_t *app) {</div><div class="line">  <span class="comment">/* Loop and handle events */</span></div><div class="line">  <span class="keywordflow">do</span> {</div><div class
 ="line">    <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events = <a name="a51"></a><a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(app-&gt;proactor);</div><div class="line">    <span class="keywordflow">for</span> (<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e = <a name="a52"></a><a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a>(events); e; e = <a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a>(events)) {</div><div class="line">      <span class="keywordflow">if</span> (!handle(app, e)) {</div><div class="line">        <span class="keywordflow">return</span>;</div><div class="line">      }</div><div class="line">    }</div><div class="line">    <a name="a53"></a><a class="code" href="group__proactor.html#gade60ff2292b74841766f953b9062
 85c0">pn_proactor_done</a>(app-&gt;proactor, events);</div><div class="line">  } <span class="keywordflow">while</span>(<span class="keyword">true</span>);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">  <span class="keyword">struct </span>app_data_t app = {0};</div><div class="line">  <span class="keywordtype">int</span> i = 0;</div><div class="line">  app.container_id = argv[i++];   <span class="comment">/* Should be unique */</span></div><div class="line">  app.host = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;&quot;</span>;</div><div class="line">  app.port = (argc &gt; 1) ? argv[i++] : <span class="stringliteral">&quot;amqp&quot;</span>;</div><div class="line">  app.amqp_address = (argc &gt; i) ? argv[i++] : <span class="stringliteral">&quot;examples&quot;</span>;</div><div class=
 "line">  app.message_count = (argc &gt; i) ? atoi(argv[i++]) : 10;</div><div class="line"></div><div class="line">  <span class="comment">/* Create the proactor and connect */</span></div><div class="line">  app.proactor = <a name="a54"></a><a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>();</div><div class="line">  <span class="keywordtype">char</span> addr[<a name="a55"></a><a class="code" href="group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256">PN_MAX_ADDR</a>];</div><div class="line">  <a name="a56"></a><a class="code" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a>(addr, <span class="keyword">sizeof</span>(addr), app.host, app.port);</div><div class="line">  <a name="a57"></a><a class="code" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a>(app.proactor, <a name="a58"></a><a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_
 connection</a>(), addr);</div><div class="line">  run(&amp;app);</div><div class="line">  <a name="a59"></a><a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(app.proactor);</div><div class="line">  <span class="keywordflow">return</span> exit_code;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[33/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex4.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex4.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex4.js
index 81514fb..276334e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex4.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex4.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX4 =
 {
-"group__message.html#gacb97f21822b058b6297bc618f6d190b0":[2,0,4,35],
-"group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd":[2,0,4,30],
-"group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd":[4,0,0,10,30],
-"group__message.html#gad169c319e27eacf91864da26a23b6d74":[4,0,0,10,21],
-"group__message.html#gad169c319e27eacf91864da26a23b6d74":[2,0,4,21],
-"group__message.html#gad514ef95e642698876bedf6ec772eb72":[2,0,4,17],
-"group__message.html#gad514ef95e642698876bedf6ec772eb72":[4,0,0,10,17],
-"group__message.html#gad7d3aa060b7666dce6a6d955945bedce":[4,0,0,10,20],
-"group__message.html#gad7d3aa060b7666dce6a6d955945bedce":[2,0,4,20],
-"group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2":[4,0,0,10,1],
-"group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2":[2,0,4,1],
-"group__message.html#gadadb16710eccb6d332d039acc9dc1042":[4,0,0,10,48],
-"group__message.html#gadadb16710eccb6d332d039acc9dc1042":[2,0,4,48],
-"group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c":[4,0,0,10,26],
-"group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c":[2,0,4,26],
-"group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3":[2,0,4,14],
-"group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3":[4,0,0,10,14],
-"group__message.html#gaf9e131dcfb094bebc3424661042d3c36":[4,0,0,10,9],
-"group__message.html#gaf9e131dcfb094bebc3424661042d3c36":[2,0,4,9],
-"group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b":[2,0,4,36],
-"group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b":[4,0,0,10,36],
-"group__messenger.html":[2,4],
-"group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1":[4,0,0,11,44],
-"group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1":[2,4,44],
-"group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2":[4,0,0,11,25],
-"group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2":[2,4,25],
-"group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74":[4,0,0,11,17],
-"group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74":[2,4,17],
-"group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958":[4,0,0,11,11],
-"group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958":[2,4,11],
-"group__messenger.html#ga06c3a066422f8a966523b43a61f62eb9":[4,0,0,11,56],
-"group__messenger.html#ga06c3a066422f8a966523b43a61f62eb9":[2,4,56],
-"group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb":[4,0,0,11,18],
-"group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb":[2,4,18],
-"group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1":[4,0,0,11,3],
-"group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1":[2,4,3],
-"group__messenger.html#ga118fb0c2384257dff5d72eea787e4a0c":[4,0,0,11,2],
-"group__messenger.html#ga118fb0c2384257dff5d72eea787e4a0c":[2,4,2],
-"group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7":[4,0,0,11,53],
-"group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7":[2,4,53],
-"group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6":[4,0,0,11,42],
-"group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6":[2,4,42],
-"group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6":[4,0,0,11,48],
-"group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6":[2,4,48],
-"group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b":[4,0,0,11,10],
-"group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b":[2,4,10],
-"group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b":[4,0,0,11,61],
-"group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b":[2,4,61],
-"group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c":[4,0,0,11,54],
-"group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c":[2,4,54],
-"group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b":[4,0,0,11,6],
-"group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b":[2,4,6],
-"group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10":[4,0,0,11,37],
-"group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10":[2,4,37],
-"group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a":[4,0,0,11,14],
-"group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a":[2,4,14],
-"group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257":[2,4,57],
-"group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257":[4,0,0,11,57],
-"group__messenger.html#ga45d578f39673ad59ca65d2042054abee":[4,0,0,11,28],
-"group__messenger.html#ga45d578f39673ad59ca65d2042054abee":[2,4,28],
-"group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d":[4,0,0,11,43],
-"group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d":[2,4,43],
-"group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4":[4,0,0,11,45],
-"group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4":[2,4,45],
-"group__messenger.html#ga480a8623fab904690218c0c67493232f":[4,0,0,11,34],
-"group__messenger.html#ga480a8623fab904690218c0c67493232f":[2,4,34],
-"group__messenger.html#ga530295575eda95e3c19316d41bd1baa7":[4,0,0,11,23],
-"group__messenger.html#ga530295575eda95e3c19316d41bd1baa7":[2,4,23],
-"group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6":[4,0,0,11,68],
-"group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6":[2,4,68],
-"group__messenger.html#ga63805c35f18ef041c69a14564dc1bce4":[4,0,0,11,21],
-"group__messenger.html#ga63805c35f18ef041c69a14564dc1bce4":[2,4,21],
-"group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0":[2,4,41],
-"group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0":[4,0,0,11,41],
-"group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2":[2,4,13],
-"group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2":[4,0,0,11,13],
-"group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6":[4,0,0,11,66],
-"group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6":[2,4,66],
-"group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9":[2,4,0],
-"group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9":[4,0,0,11,0],
-"group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e":[4,0,0,11,58],
-"group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e":[2,4,58],
-"group__messenger.html#ga6fa594235e316cd2a04b44b283194a43":[4,0,0,11,30],
-"group__messenger.html#ga6fa594235e316cd2a04b44b283194a43":[2,4,30],
-"group__messenger.html#ga71197163a69770575df74e3cee617429":[4,0,0,11,8],
-"group__messenger.html#ga71197163a69770575df74e3cee617429":[2,4,8],
-"group__messenger.html#ga757aeef23d47ecc2a9a461b882686417":[2,4,35],
-"group__messenger.html#ga757aeef23d47ecc2a9a461b882686417":[4,0,0,11,35],
-"group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e":[4,0,0,11,64],
-"group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e":[2,4,64],
-"group__messenger.html#ga8521b0999200c076bf12568ac10fe925":[2,4,60],
-"group__messenger.html#ga8521b0999200c076bf12568ac10fe925":[4,0,0,11,60],
-"group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787":[4,0,0,11,36],
-"group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787":[2,4,36],
-"group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e":[2,4,38],
-"group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e":[4,0,0,11,38],
-"group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2":[4,0,0,11,16],
-"group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2":[2,4,16],
-"group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc":[4,0,0,11,27],
-"group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc":[2,4,27],
-"group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7":[2,4,67],
-"group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7":[4,0,0,11,67],
-"group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f":[4,0,0,11,46],
-"group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f":[2,4,46],
-"group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085":[2,4,63],
-"group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085":[4,0,0,11,63],
-"group__messenger.html#gaa6d85929e4b4b574690927ddde00c540":[4,0,0,11,50],
-"group__messenger.html#gaa6d85929e4b4b574690927ddde00c540":[2,4,50],
-"group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7":[4,0,0,11,5],
-"group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7":[2,4,5],
-"group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1":[2,4,12],
-"group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1":[4,0,0,11,12],
-"group__messenger.html#gabd73703511b9dae193765e9e57864291":[2,4,4],
-"group__messenger.html#gabd73703511b9dae193765e9e57864291":[4,0,0,11,4],
-"group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433":[4,0,0,11,7],
-"group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433":[2,4,7],
-"group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1":[2,4,26],
-"group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1":[4,0,0,11,26],
-"group__messenger.html#gac36589fe5dc0378cf62558e40060a26f":[4,0,0,11,33],
-"group__messenger.html#gac36589fe5dc0378cf62558e40060a26f":[2,4,33],
-"group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff":[2,4,59],
-"group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff":[4,0,0,11,59],
-"group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0":[4,0,0,11,22],
-"group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0":[2,4,22],
-"group__messenger.html#gacf39b77df62750343e2f4e90dbcacc75":[2,4,62],
-"group__messenger.html#gacf39b77df62750343e2f4e90dbcacc75":[4,0,0,11,62],
-"group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c":[2,4,24],
-"group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c":[4,0,0,11,24],
-"group__messenger.html#gad398544ad1374f67c922115ae1cceacc":[2,4,40],
-"group__messenger.html#gad398544ad1374f67c922115ae1cceacc":[4,0,0,11,40],
-"group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14":[2,4,1],
-"group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14":[4,0,0,11,1],
-"group__messenger.html#gad61fff52c28501171ecbb0b21bbde954":[2,4,9],
-"group__messenger.html#gad61fff52c28501171ecbb0b21bbde954":[4,0,0,11,9],
-"group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b":[2,4,15],
-"group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b":[4,0,0,11,15],
-"group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c":[2,4,31],
-"group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c":[4,0,0,11,31],
-"group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3":[2,4,29],
-"group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3":[4,0,0,11,29],
-"group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4":[2,4,32],
-"group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4":[4,0,0,11,32],
-"group__messenger.html#gae31f9a99dcbedffe83588cf25b805325":[2,4,47],
-"group__messenger.html#gae31f9a99dcbedffe83588cf25b805325":[4,0,0,11,47],
-"group__messenger.html#gae351d031d2ef29bdb137a59d461c4253":[2,4,52],
-"group__messenger.html#gae351d031d2ef29bdb137a59d461c4253":[4,0,0,11,52],
-"group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d":[2,4,55],
-"group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d":[4,0,0,11,55],
-"group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981":[2,4,20],
-"group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981":[4,0,0,11,20],
-"group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1":[2,4,65],
-"group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1":[4,0,0,11,65],
-"group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5":[2,4,49],
-"group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5":[4,0,0,11,49],
-"group__messenger.html#gaf572cbf224105d08898d2906336712f7":[4,0,0,11,19],
-"group__messenger.html#gaf572cbf224105d08898d2906336712f7":[2,4,19],
-"group__messenger.html#gafe31e771826f8107d93fc276c9715aab":[4,0,0,11,51],
-"group__messenger.html#gafe31e771826f8107d93fc276c9715aab":[2,4,51],
-"group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a":[2,4,39],
-"group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a":[4,0,0,11,39],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2":[2,4,6,0],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2":[4,0,0,11,6,0],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583":[2,4,6,7],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583":[4,0,0,11,6,7],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee":[2,4,6,6],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee":[4,0,0,11,6,6],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611":[2,4,6,1],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611":[4,0,0,11,6,1],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852":[2,4,6,4],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852":[4,0,0,11,6,4],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467":[4,0,0,11,6,2],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467":[2,4,6,2],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8":[4,0,0,11,6,5],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8":[2,4,6,5],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf":[2,4,6,3],
-"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf":[4,0,0,11,6,3],
-"group__proactor.html":[2,3,0],
-"group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58":[2,3,0,6],
-"group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58":[4,0,0,12,4],
-"group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560":[4,0,0,13,14],
-"group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560":[2,3,0,21],
-"group__proactor.html#ga1950236260353f82729dbb4589ef6c27":[4,0,0,13,13],
-"group__proactor.html#ga1950236260353f82729dbb4589ef6c27":[2,3,0,20],
-"group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256":[4,0,0,13,0],
-"group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256":[2,3,0,0],
-"group__proactor.html#ga2b66a46f3e557010ec61bd105326753d":[4,0,0,13,7],
-"group__proactor.html#ga2b66a46f3e557010ec61bd105326753d":[2,3,0,14],
-"group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40":[2,3,0,22],
-"group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40":[4,0,0,13,15],
-"group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf":[4,0,0,13,3],
-"group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf":[2,3,0,10],
-"group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0":[4,0,0,12,3],
-"group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0":[2,3,0,5],
-"group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c":[4,0,0,12,0],
-"group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c":[2,3,0,1],
-"group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b":[2,3,0,4],
-"group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b":[4,0,0,12,2],
-"group__proactor.html#ga957eae24db6ec4962af79c5a06106115":[2,3,0,15],
-"group__proactor.html#ga957eae24db6ec4962af79c5a06106115":[4,0,0,13,8],
-"group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6":[4,0,0,13,4],
-"group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6":[2,3,0,11],
-"group__proactor.html#ga9f6a27999303c6082edc581f880de37c":[2,3,0,3],
-"group__proactor.html#ga9f6a27999303c6082edc581f880de37c":[4,0,0,12,1],
-"group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711":[2,3,0,17],
-"group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711":[4,0,0,13,10],
-"group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc":[2,3,0,2],
-"group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc":[4,0,0,19,18],
-"group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f":[4,0,0,13,12],
-"group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f":[2,3,0,19],
-"group__proactor.html#gac2a925b3de00efd8cd40fa9920169554":[4,0,0,13,2],
-"group__proactor.html#gac2a925b3de00efd8cd40fa9920169554":[2,3,0,9],
-"group__proactor.html#gac412771217decd84bd70931acbd0828a":[4,0,0,13,16],
-"group__proactor.html#gac412771217decd84bd70931acbd0828a":[2,3,0,23],
-"group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68":[4,0,0,13,6],
-"group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68":[2,3,0,13],
-"group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752":[2,3,0,12],
-"group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752":[4,0,0,13,5],
-"group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d":[2,3,0,24],
-"group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d":[4,0,0,13,17],
-"group__proactor.html#gad7cd71f06282eb290699d90c316b2d32":[2,3,0,18],
-"group__proactor.html#gad7cd71f06282eb290699d90c316b2d32":[4,0,0,13,11],
-"group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c":[4,0,0,12,5],
-"group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c":[2,3,0,7],
-"group__proactor.html#gade60ff2292b74841766f953b906285c0":[4,0,0,13,9],
-"group__proactor.html#gade60ff2292b74841766f953b906285c0":[2,3,0,16],
-"group__proactor.html#gaf67a7642c9003b36255b58776b494c96":[4,0,0,13,1],
-"group__proactor.html#gaf67a7642c9003b36255b58776b494c96":[2,3,0,8],
-"group__proactor__events.html":[2,3,1],
-"group__sasl.html":[2,0,9],
-"group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283":[2,0,9,4],
-"group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283":[4,0,0,14,4],
-"group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6":[2,0,9,5],
-"group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6":[4,0,0,14,5],
-"group__sasl.html#ga1737191972d5dded0993bf1431e71df0":[4,0,0,14,3],
-"group__sasl.html#ga1737191972d5dded0993bf1431e71df0":[2,0,9,3],
-"group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0":[2,0,9,0],
-"group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0":[4,0,0,14,0],
-"group__sasl.html#ga700e1d505068f895383dd932af55987e":[2,0,9,6],
-"group__sasl.html#ga700e1d505068f895383dd932af55987e":[4,0,0,14,6],
-"group__sasl.html#ga73299a6a22e141e7911a739590032625":[4,0,0,14,8],
-"group__sasl.html#ga73299a6a22e141e7911a739590032625":[2,0,9,8],
-"group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c":[2,0,9,2],
-"group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c":[4,0,0,14,2],
-"group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863":[4,0,0,14,7],
-"group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863":[2,0,9,7],
-"group__sasl.html#gabf4176414424ce02a4e03b4338d30521":[2,0,9,12],
-"group__sasl.html#gabf4176414424ce02a4e03b4338d30521":[4,0,0,14,12],
-"group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243":[4,0,0,14,10],
-"group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243":[2,0,9,10],
-"group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56":[2,0,9,11]
+"group__message.html#gaa8594da8507dc031b1e0e89d51a2f281":[3,0,4,27],
+"group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313":[5,0,0,15,29],
+"group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313":[3,0,4,29],
+"group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e":[3,0,4,2],
+"group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e":[5,0,0,15,2],
+"group__message.html#gab0bae90838f4661b0c82c15f25e1e988":[5,0,0,15,51],
+"group__message.html#gab0bae90838f4661b0c82c15f25e1e988":[3,0,4,51],
+"group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2":[3,0,4,40],
+"group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2":[5,0,0,15,40],
+"group__message.html#gac10c5d8f12e4817fec126fdb608baf53":[5,0,0,15,5],
+"group__message.html#gac10c5d8f12e4817fec126fdb608baf53":[3,0,4,5],
+"group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2":[5,0,0,15,15],
+"group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2":[3,0,4,15],
+"group__message.html#gacb97f21822b058b6297bc618f6d190b0":[3,0,4,35],
+"group__message.html#gacb97f21822b058b6297bc618f6d190b0":[5,0,0,15,35],
+"group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd":[5,0,0,15,30],
+"group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd":[3,0,4,30],
+"group__message.html#gad169c319e27eacf91864da26a23b6d74":[3,0,4,21],
+"group__message.html#gad169c319e27eacf91864da26a23b6d74":[5,0,0,15,21],
+"group__message.html#gad514ef95e642698876bedf6ec772eb72":[3,0,4,17],
+"group__message.html#gad514ef95e642698876bedf6ec772eb72":[5,0,0,15,17],
+"group__message.html#gad7d3aa060b7666dce6a6d955945bedce":[3,0,4,20],
+"group__message.html#gad7d3aa060b7666dce6a6d955945bedce":[5,0,0,15,20],
+"group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2":[3,0,4,1],
+"group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2":[5,0,0,15,1],
+"group__message.html#gadadb16710eccb6d332d039acc9dc1042":[5,0,0,15,48],
+"group__message.html#gadadb16710eccb6d332d039acc9dc1042":[3,0,4,48],
+"group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c":[3,0,4,26],
+"group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c":[5,0,0,15,26],
+"group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3":[3,0,4,14],
+"group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3":[5,0,0,15,14],
+"group__message.html#gaf9e131dcfb094bebc3424661042d3c36":[3,0,4,9],
+"group__message.html#gaf9e131dcfb094bebc3424661042d3c36":[5,0,0,15,9],
+"group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b":[3,0,4,36],
+"group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b":[5,0,0,15,36],
+"group__messenger.html":[3,4],
+"group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1":[5,0,0,16,44],
+"group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1":[3,4,44],
+"group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2":[5,0,0,16,25],
+"group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2":[3,4,25],
+"group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74":[5,0,0,16,17],
+"group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74":[3,4,17],
+"group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958":[5,0,0,16,11],
+"group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958":[3,4,11],
+"group__messenger.html#ga06c3a066422f8a966523b43a61f62eb9":[3,4,56],
+"group__messenger.html#ga06c3a066422f8a966523b43a61f62eb9":[5,0,0,16,56],
+"group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb":[5,0,0,16,18],
+"group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb":[3,4,18],
+"group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1":[5,0,0,16,3],
+"group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1":[3,4,3],
+"group__messenger.html#ga118fb0c2384257dff5d72eea787e4a0c":[5,0,0,16,2],
+"group__messenger.html#ga118fb0c2384257dff5d72eea787e4a0c":[3,4,2],
+"group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7":[5,0,0,16,53],
+"group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7":[3,4,53],
+"group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6":[5,0,0,16,42],
+"group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6":[3,4,42],
+"group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6":[5,0,0,16,48],
+"group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6":[3,4,48],
+"group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b":[5,0,0,16,10],
+"group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b":[3,4,10],
+"group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b":[5,0,0,16,61],
+"group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b":[3,4,61],
+"group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c":[3,4,54],
+"group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c":[5,0,0,16,54],
+"group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b":[5,0,0,16,6],
+"group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b":[3,4,6],
+"group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10":[5,0,0,16,37],
+"group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10":[3,4,37],
+"group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a":[5,0,0,16,14],
+"group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a":[3,4,14],
+"group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257":[5,0,0,16,57],
+"group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257":[3,4,57],
+"group__messenger.html#ga45d578f39673ad59ca65d2042054abee":[5,0,0,16,28],
+"group__messenger.html#ga45d578f39673ad59ca65d2042054abee":[3,4,28],
+"group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d":[3,4,43],
+"group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d":[5,0,0,16,43],
+"group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4":[5,0,0,16,45],
+"group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4":[3,4,45],
+"group__messenger.html#ga480a8623fab904690218c0c67493232f":[5,0,0,16,34],
+"group__messenger.html#ga480a8623fab904690218c0c67493232f":[3,4,34],
+"group__messenger.html#ga530295575eda95e3c19316d41bd1baa7":[5,0,0,16,23],
+"group__messenger.html#ga530295575eda95e3c19316d41bd1baa7":[3,4,23],
+"group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6":[3,4,68],
+"group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6":[5,0,0,16,68],
+"group__messenger.html#ga63805c35f18ef041c69a14564dc1bce4":[5,0,0,16,21],
+"group__messenger.html#ga63805c35f18ef041c69a14564dc1bce4":[3,4,21],
+"group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0":[5,0,0,16,41],
+"group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0":[3,4,41],
+"group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2":[5,0,0,16,13],
+"group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2":[3,4,13],
+"group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6":[3,4,66],
+"group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6":[5,0,0,16,66],
+"group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9":[5,0,0,16,0],
+"group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9":[3,4,0],
+"group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e":[3,4,58],
+"group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e":[5,0,0,16,58],
+"group__messenger.html#ga6fa594235e316cd2a04b44b283194a43":[5,0,0,16,30],
+"group__messenger.html#ga6fa594235e316cd2a04b44b283194a43":[3,4,30],
+"group__messenger.html#ga71197163a69770575df74e3cee617429":[5,0,0,16,8],
+"group__messenger.html#ga71197163a69770575df74e3cee617429":[3,4,8],
+"group__messenger.html#ga757aeef23d47ecc2a9a461b882686417":[3,4,35],
+"group__messenger.html#ga757aeef23d47ecc2a9a461b882686417":[5,0,0,16,35],
+"group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e":[3,4,64],
+"group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e":[5,0,0,16,64],
+"group__messenger.html#ga8521b0999200c076bf12568ac10fe925":[3,4,60],
+"group__messenger.html#ga8521b0999200c076bf12568ac10fe925":[5,0,0,16,60],
+"group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787":[3,4,36],
+"group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787":[5,0,0,16,36],
+"group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e":[5,0,0,16,38],
+"group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e":[3,4,38],
+"group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2":[5,0,0,16,16],
+"group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2":[3,4,16],
+"group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc":[3,4,27],
+"group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc":[5,0,0,16,27],
+"group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7":[3,4,67],
+"group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7":[5,0,0,16,67],
+"group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f":[5,0,0,16,46],
+"group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f":[3,4,46],
+"group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085":[5,0,0,16,63],
+"group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085":[3,4,63],
+"group__messenger.html#gaa6d85929e4b4b574690927ddde00c540":[3,4,50],
+"group__messenger.html#gaa6d85929e4b4b574690927ddde00c540":[5,0,0,16,50],
+"group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7":[5,0,0,16,5],
+"group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7":[3,4,5],
+"group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1":[5,0,0,16,12],
+"group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1":[3,4,12],
+"group__messenger.html#gabd73703511b9dae193765e9e57864291":[5,0,0,16,4],
+"group__messenger.html#gabd73703511b9dae193765e9e57864291":[3,4,4],
+"group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433":[3,4,7],
+"group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433":[5,0,0,16,7],
+"group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1":[5,0,0,16,26],
+"group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1":[3,4,26],
+"group__messenger.html#gac36589fe5dc0378cf62558e40060a26f":[3,4,33],
+"group__messenger.html#gac36589fe5dc0378cf62558e40060a26f":[5,0,0,16,33],
+"group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff":[3,4,59],
+"group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff":[5,0,0,16,59],
+"group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0":[3,4,22],
+"group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0":[5,0,0,16,22],
+"group__messenger.html#gacf39b77df62750343e2f4e90dbcacc75":[3,4,62],
+"group__messenger.html#gacf39b77df62750343e2f4e90dbcacc75":[5,0,0,16,62],
+"group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c":[3,4,24],
+"group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c":[5,0,0,16,24],
+"group__messenger.html#gad398544ad1374f67c922115ae1cceacc":[3,4,40],
+"group__messenger.html#gad398544ad1374f67c922115ae1cceacc":[5,0,0,16,40],
+"group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14":[5,0,0,16,1],
+"group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14":[3,4,1],
+"group__messenger.html#gad61fff52c28501171ecbb0b21bbde954":[5,0,0,16,9],
+"group__messenger.html#gad61fff52c28501171ecbb0b21bbde954":[3,4,9],
+"group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b":[5,0,0,16,15],
+"group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b":[3,4,15],
+"group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c":[3,4,31],
+"group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c":[5,0,0,16,31],
+"group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3":[3,4,29],
+"group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3":[5,0,0,16,29],
+"group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4":[3,4,32],
+"group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4":[5,0,0,16,32],
+"group__messenger.html#gae31f9a99dcbedffe83588cf25b805325":[3,4,47],
+"group__messenger.html#gae31f9a99dcbedffe83588cf25b805325":[5,0,0,16,47],
+"group__messenger.html#gae351d031d2ef29bdb137a59d461c4253":[3,4,52],
+"group__messenger.html#gae351d031d2ef29bdb137a59d461c4253":[5,0,0,16,52],
+"group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d":[3,4,55],
+"group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d":[5,0,0,16,55],
+"group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981":[3,4,20],
+"group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981":[5,0,0,16,20],
+"group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1":[5,0,0,16,65],
+"group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1":[3,4,65],
+"group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5":[3,4,49],
+"group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5":[5,0,0,16,49],
+"group__messenger.html#gaf572cbf224105d08898d2906336712f7":[5,0,0,16,19],
+"group__messenger.html#gaf572cbf224105d08898d2906336712f7":[3,4,19],
+"group__messenger.html#gafe31e771826f8107d93fc276c9715aab":[3,4,51],
+"group__messenger.html#gafe31e771826f8107d93fc276c9715aab":[5,0,0,16,51],
+"group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a":[3,4,39],
+"group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a":[5,0,0,16,39],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2":[3,4,6,0],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2":[5,0,0,16,6,0],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583":[3,4,6,7],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583":[5,0,0,16,6,7],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee":[3,4,6,6],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee":[5,0,0,16,6,6],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611":[3,4,6,1],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611":[5,0,0,16,6,1],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852":[5,0,0,16,6,4],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852":[3,4,6,4],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467":[3,4,6,2],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467":[5,0,0,16,6,2],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8":[5,0,0,16,6,5],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8":[3,4,6,5],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf":[3,4,6,3],
+"group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf":[5,0,0,16,6,3],
+"group__proactor.html":[3,3,0],
+"group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58":[5,0,0,17,6],
+"group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58":[3,3,0,8],
+"group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560":[5,0,0,19,15],
+"group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560":[3,3,0,28],
+"group__proactor.html#ga1950236260353f82729dbb4589ef6c27":[5,0,0,19,14],
+"group__proactor.html#ga1950236260353f82729dbb4589ef6c27":[3,3,0,27],
+"group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256":[5,0,0,19,0],
+"group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256":[3,3,0,0],
+"group__proactor.html#ga2b66a46f3e557010ec61bd105326753d":[3,3,0,21],
+"group__proactor.html#ga2b66a46f3e557010ec61bd105326753d":[5,0,0,19,8],
+"group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39":[3,3,0,5],
+"group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39":[5,0,0,17,3],
+"group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40":[3,3,0,29],
+"group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40":[5,0,0,19,16],
+"group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf":[3,3,0,16],
+"group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf":[5,0,0,19,3],
+"group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0":[3,3,0,12],
+"group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0":[5,0,0,17,10],
+"group__proactor.html#ga6163449ac3b87782628448f192930eb0":[5,0,0,17,5],
+"group__proactor.html#ga6163449ac3b87782628448f192930eb0":[3,3,0,7],
+"group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c":[3,3,0,1],
+"group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c":[5,0,0,17,0],
+"group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b":[5,0,0,17,9],
+"group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b":[3,3,0,11],
+"group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148":[3,3,0,4],
+"group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148":[5,0,0,17,2],
+"group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b":[5,0,0,17,8],
+"group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b":[3,3,0,10],
+"group__proactor.html#ga955471a53dd486a6f227d8d57322a44c":[3,3,0,13],
+"group__proactor.html#ga955471a53dd486a6f227d8d57322a44c":[5,0,0,17,11],
+"group__proactor.html#ga957eae24db6ec4962af79c5a06106115":[5,0,0,19,9],
+"group__proactor.html#ga957eae24db6ec4962af79c5a06106115":[3,3,0,22],
+"group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6":[3,3,0,18],
+"group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6":[5,0,0,19,5],
+"group__proactor.html#ga9f6a27999303c6082edc581f880de37c":[5,0,0,17,1],
+"group__proactor.html#ga9f6a27999303c6082edc581f880de37c":[3,3,0,3],
+"group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711":[5,0,0,19,11],
+"group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711":[3,3,0,24],
+"group__proactor.html#gabb093e51449351cf5530bb300bd67ba1":[3,3,0,17],
+"group__proactor.html#gabb093e51449351cf5530bb300bd67ba1":[5,0,0,19,4],
+"group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc":[5,0,0,29,18],
+"group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc":[3,3,0,2],
+"group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f":[5,0,0,19,13],
+"group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f":[3,3,0,26],
+"group__proactor.html#gac2a925b3de00efd8cd40fa9920169554":[5,0,0,19,2],
+"group__proactor.html#gac2a925b3de00efd8cd40fa9920169554":[3,3,0,15],
+"group__proactor.html#gac412771217decd84bd70931acbd0828a":[5,0,0,19,17],
+"group__proactor.html#gac412771217decd84bd70931acbd0828a":[3,3,0,30],
+"group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68":[3,3,0,20],
+"group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68":[5,0,0,19,7],
+"group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752":[3,3,0,19],
+"group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752":[5,0,0,19,6],
+"group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9":[5,0,0,17,4],
+"group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9":[3,3,0,6],
+"group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d":[5,0,0,19,18],
+"group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d":[3,3,0,31],
+"group__proactor.html#gad7cd71f06282eb290699d90c316b2d32":[3,3,0,25],
+"group__proactor.html#gad7cd71f06282eb290699d90c316b2d32":[5,0,0,19,12],
+"group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c":[3,3,0,9]
 };

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex5.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex5.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex5.js
index 67ba355..86da7df 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex5.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex5.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX5 =
 {
-"group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56":[4,0,0,14,11],
-"group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b":[4,0,0,14,1],
-"group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b":[2,0,9,1],
-"group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315":[2,0,9,9],
-"group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315":[4,0,0,14,9],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e":[4,0,0,14,1,1],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e":[2,0,9,1,0],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191":[2,0,9,1,3],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191":[4,0,0,14,1,4],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba1c90ef54986e694f0d94036977681785":[4,0,0,14,1,0],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a":[2,0,9,1,1],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a":[4,0,0,14,1,2],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939":[4,0,0,14,1,3],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939":[2,0,9,1,2],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3":[2,0,9,1,4],
-"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3":[4,0,0,14,1,5],
-"group__session.html":[2,0,1],
-"group__session.html#ga0128a4413f413569b91e2bc78217728a":[4,0,0,15,4],
-"group__session.html#ga0128a4413f413569b91e2bc78217728a":[2,0,1,5],
-"group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532":[2,0,1,3],
-"group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532":[4,0,0,15,2],
-"group__session.html#ga0f95b5177494a68991d75444c2f6f812":[2,0,1,2],
-"group__session.html#ga0f95b5177494a68991d75444c2f6f812":[4,0,0,15,1],
-"group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5":[4,0,0,15,11],
-"group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5":[2,0,1,12],
-"group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde":[2,0,1,7],
-"group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde":[4,0,0,15,6],
-"group__session.html#ga1fdeb3d6606e869790a228d847136cb0":[2,0,1,13],
-"group__session.html#ga1fdeb3d6606e869790a228d847136cb0":[4,0,0,15,12],
-"group__session.html#ga1feff407b8fe308a14f283d193246f3c":[4,0,0,15,0],
-"group__session.html#ga1feff407b8fe308a14f283d193246f3c":[2,0,1,1],
-"group__session.html#ga238754f924f84597056f3249a7e7a35f":[4,0,0,15,19],
-"group__session.html#ga238754f924f84597056f3249a7e7a35f":[2,0,1,20],
-"group__session.html#ga2b345eada2c15249caaefaa894d1aae3":[2,0,1,11],
-"group__session.html#ga2b345eada2c15249caaefaa894d1aae3":[4,0,0,15,10],
-"group__session.html#ga31f2e4cc76135f79e96453aa72d441b2":[2,0,1,4],
-"group__session.html#ga31f2e4cc76135f79e96453aa72d441b2":[4,0,0,15,3],
-"group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9":[4,0,0,19,12],
-"group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9":[2,0,1,0],
-"group__session.html#ga55a8429e178831556844ab251ef67c77":[2,0,1,18],
-"group__session.html#ga55a8429e178831556844ab251ef67c77":[4,0,0,15,17],
-"group__session.html#ga577d6f6659958c5d89cd56e944fbd999":[4,0,0,15,18],
-"group__session.html#ga577d6f6659958c5d89cd56e944fbd999":[2,0,1,19],
-"group__session.html#ga7e2a4567e3488a225257e4d883a7e78f":[4,0,0,15,5],
-"group__session.html#ga7e2a4567e3488a225257e4d883a7e78f":[2,0,1,6],
-"group__session.html#ga931b89bd737ab293056cb695dddd9800":[2,0,1,15],
-"group__session.html#ga931b89bd737ab293056cb695dddd9800":[4,0,0,15,14],
-"group__session.html#gaa45a8aa758334528a86cb7914ebe8545":[2,0,1,10],
-"group__session.html#gaa45a8aa758334528a86cb7914ebe8545":[4,0,0,15,9],
-"group__session.html#gabcae388cdcb33e976b490525ec600b50":[2,0,1,17],
-"group__session.html#gabcae388cdcb33e976b490525ec600b50":[4,0,0,15,16],
-"group__session.html#gaca5962e539688b4f31b5b91136aa3c79":[2,0,1,16],
-"group__session.html#gaca5962e539688b4f31b5b91136aa3c79":[4,0,0,15,15],
-"group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece":[2,0,1,9],
-"group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece":[4,0,0,15,8],
-"group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9":[2,0,1,14],
-"group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9":[4,0,0,15,13],
-"group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3":[4,0,0,15,7],
-"group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3":[2,0,1,8],
-"group__ssl.html":[2,0,10],
-"group__ssl.html#ga03e8070271747c3901d8d6e5710c0066":[4,0,0,16,18],
-"group__ssl.html#ga03e8070271747c3901d8d6e5710c0066":[2,0,10,18],
-"group__ssl.html#ga0c9e8827536b9929793045771d82bdf1":[4,0,0,16,24],
-"group__ssl.html#ga0c9e8827536b9929793045771d82bdf1":[2,0,10,24],
-"group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225":[2,0,10,2],
-"group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225":[4,0,0,16,2],
-"group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3":[2,0,10,22],
-"group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3":[4,0,0,16,22],
-"group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a":[4,0,0,16,20],
-"group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a":[2,0,10,20],
-"group__ssl.html#ga215da63662423b00d34605ba4f9761f5":[2,0,10,1],
-"group__ssl.html#ga215da63662423b00d34605ba4f9761f5":[4,0,0,16,1],
-"group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74":[4,0,0,16,13],
-"group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74":[2,0,10,13],
-"group__ssl.html#ga324db5da83b1abad2e948481d65119d4":[2,0,10,23],
-"group__ssl.html#ga324db5da83b1abad2e948481d65119d4":[4,0,0,16,23],
-"group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11":[4,0,0,16,12],
-"group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11":[2,0,10,12],
-"group__ssl.html#ga45f319dd31ad456b8a85927888f94acf":[2,0,10,15],
-"group__ssl.html#ga45f319dd31ad456b8a85927888f94acf":[4,0,0,16,15],
-"group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52":[4,0,0,16,16],
-"group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52":[2,0,10,16],
-"group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d":[4,0,0,16,9],
-"group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d":[2,0,10,9],
-"group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f":[4,0,0,16,19],
-"group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f":[2,0,10,19],
-"group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40":[2,0,10,5],
-"group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40":[4,0,0,16,5],
-"group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d":[4,0,0,16,11],
-"group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d":[2,0,10,11],
-"group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa":[4,0,0,16,10],
-"group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa":[2,0,10,10],
-"group__ssl.html#ga76636a5ce4696284356321226ee0731c":[4,0,0,16,21],
-"group__ssl.html#ga76636a5ce4696284356321226ee0731c":[2,0,10,21],
-"group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d":[4,0,0,16,17],
-"group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d":[2,0,10,17],
-"group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357":[4,0,0,16,8],
-"group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357":[2,0,10,8],
-"group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c":[4,0,0,16,14],
-"group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c":[2,0,10,14],
-"group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175":[4,0,0,16,0],
-"group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175":[2,0,10,0],
-"group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb":[4,0,0,16,4],
-"group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb":[2,0,10,4],
-"group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb":[2,0,10,7],
-"group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb":[4,0,0,16,7],
-"group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892":[4,0,0,16,6],
-"group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892":[2,0,10,6],
-"group__ssl.html#gaf175c116d52a91001f9a3559b580f56d":[4,0,0,16,3],
-"group__ssl.html#gaf175c116d52a91001f9a3559b580f56d":[2,0,10,3],
-"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078":[2,0,10,2,1],
-"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078":[4,0,0,16,2,1],
-"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c":[4,0,0,16,2,0],
-"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c":[2,0,10,2,0],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a0eb5c598625be198fe7220e7f8bc5e18":[4,0,0,16,5,2],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a2161af8cc70236ebe4635ef6a3002649":[4,0,0,16,5,4],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a641ed18c339dabbb246b88b3ed6ecda0":[4,0,0,16,5,3],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40ad39c582ed1f0d3a1f97c17b9432028d6":[4,0,0,16,5,5],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40aeab893d2607ef1ab90e89ba42df33e71":[4,0,0,16,5,1],
-"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40af5c1deffedaaae563e493e23e7658aa0":[4,0,0,16,5,0],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36":[2,0,10,4,3],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36":[4,0,0,16,4,3],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44":[4,0,0,16,4,1],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44":[2,0,10,4,1],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc":[2,0,10,4,0],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc":[4,0,0,16,4,0],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5":[2,0,10,4,2],
-"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5":[4,0,0,16,4,2],
-"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a623d60f90b7f0e636db7228e244f2ca0":[4,0,0,16,6,1],
-"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a6c5d0f29a3e5a728a9c80a10f25ac62f":[4,0,0,16,6,3],
-"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a9449a5575bf4589d1e88687a3a99748b":[4,0,0,16,6,2],
-"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892add60b6e2931ac8c35d6925e096fb3bf4":[4,0,0,16,6,0],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d":[4,0,0,16,3,2],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d":[2,0,10,3,2],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f":[4,0,0,16,3,1],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f":[2,0,10,3,1],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d":[2,0,10,3,0],
-"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d":[4,0,0,16,3,0],
-"group__terminus.html":[2,0,3],
-"group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1":[4,0,0,17,8],
-"group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1":[2,0,3,8],
-"group__terminus.html#ga0f9df2253065f81fd304f39a846e6468":[2,0,3,13],
-"group__terminus.html#ga0f9df2253065f81fd304f39a846e6468":[4,0,0,17,13],
-"group__terminus.html#ga213267363be45848f3299471ea93089b":[2,0,3,2],
-"group__terminus.html#ga213267363be45848f3299471ea93089b":[4,0,0,17,2],
-"group__terminus.html#ga2461341ae0d8c2261277837e6e20d2de":[4,0,0,17,5],
-"group__terminus.html#ga2461341ae0d8c2261277837e6e20d2de":[2,0,3,5],
-"group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a":[4,0,0,17,7],
-"group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a":[2,0,3,7],
-"group__terminus.html#ga35d4ced3a1e9056c50adf3a6e051e0d8":[4,0,0,17,21],
-"group__terminus.html#ga35d4ced3a1e9056c50adf3a6e051e0d8":[2,0,3,21],
-"group__terminus.html#ga3cb9c86d1e2bb024de2658f9def098e7":[2,0,3,1],
-"group__terminus.html#ga3cb9c86d1e2bb024de2658f9def098e7":[4,0,0,17,1],
-"group__terminus.html#ga5cc480060f3fda737a333ac7a2ea0d70":[2,0,3,20],
-"group__terminus.html#ga5cc480060f3fda737a333ac7a2ea0d70":[4,0,0,17,20],
-"group__terminus.html#ga5edfc0f1d61880e1951c21f92c19af53":[2,0,3,9],
-"group__terminus.html#ga5edfc0f1d61880e1951c21f92c19af53":[4,0,0,17,9],
-"group__terminus.html#ga62ba74b0c8fad5417a62cffe53996690":[4,0,0,17,15],
-"group__terminus.html#ga62ba74b0c8fad5417a62cffe53996690":[2,0,3,15],
-"group__terminus.html#ga7779782e173db3efcd5de211e0f935ae":[2,0,3,18],
-"group__terminus.html#ga7779782e173db3efcd5de211e0f935ae":[4,0,0,17,18],
-"group__terminus.html#ga822fceb77515b691a10bf5381e4562ec":[2,0,3,6],
-"group__terminus.html#ga822fceb77515b691a10bf5381e4562ec":[4,0,0,17,6],
-"group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d":[2,0,3,16],
-"group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d":[4,0,0,17,16],
-"group__terminus.html#gaa1ad0b04b1625ac1ba5993b6679dcfcf":[2,0,3,23],
-"group__terminus.html#gaa1ad0b04b1625ac1ba5993b6679dcfcf":[4,0,0,17,23],
-"group__terminus.html#gaaad123d27d82b2f7d051489a8bff73c6":[4,0,0,17,14],
-"group__terminus.html#gaaad123d27d82b2f7d051489a8bff73c6":[2,0,3,14],
-"group__terminus.html#gaabb94d82847495c909aab24365d048c6":[2,0,3,10],
-"group__terminus.html#gaabb94d82847495c909aab24365d048c6":[4,0,0,17,10],
-"group__terminus.html#gab4089b27ee99a348deab776f3d4931f0":[4,0,0,17,3],
-"group__terminus.html#gab4089b27ee99a348deab776f3d4931f0":[2,0,3,3],
-"group__terminus.html#gac5e15021927b18d0aa3fd712e4b0ac73":[4,0,0,17,12],
-"group__terminus.html#gac5e15021927b18d0aa3fd712e4b0ac73":[2,0,3,12],
-"group__terminus.html#gac6fb89a5fa96476db51b60f10dc785d0":[2,0,3,4],
-"group__terminus.html#gac6fb89a5fa96476db51b60f10dc785d0":[4,0,0,17,4],
-"group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2":[2,0,3,0],
-"group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2":[4,0,0,17,0],
-"group__terminus.html#gad9f06855cd6538f672c63836b8ef0ae5":[4,0,0,17,11],
-"group__terminus.html#gad9f06855cd6538f672c63836b8ef0ae5":[2,0,3,11],
-"group__terminus.html#gae9c9515f94353eb82cb421e46ce4bb24":[4,0,0,17,19],
-"group__terminus.html#gae9c9515f94353eb82cb421e46ce4bb24":[2,0,3,19],
-"group__terminus.html#gaf9d4257ba00d3e0e0f8d983324018209":[4,0,0,17,17],
-"group__terminus.html#gaf9d4257ba00d3e0e0f8d983324018209":[2,0,3,17],
-"group__terminus.html#gafb9c4b3d344dd94ae174ecd8d25f503c":[2,0,3,22],
-"group__terminus.html#gafb9c4b3d344dd94ae174ecd8d25f503c":[4,0,0,17,22],
-"group__terminus.html#gga213267363be45848f3299471ea93089ba403e259f8d858d6a12f463dbd7e5dc6b":[4,0,0,17,2,0],
-"group__terminus.html#gga213267363be45848f3299471ea93089ba403e259f8d858d6a12f463dbd7e5dc6b":[2,0,3,2,0],
-"group__terminus.html#gga213267363be45848f3299471ea93089ba95b1d5b60c47569e0358258305de1d58":[4,0,0,17,2,1],
-"group__terminus.html#gga213267363be45848f3299471ea93089ba95b1d5b60c47569e0358258305de1d58":[2,0,3,2,1],
-"group__terminus.html#gga213267363be45848f3299471ea93089bac2e0a9f773faf4ee8fd43f77855933d2":[4,0,0,17,2,2],
-"group__terminus.html#gga213267363be45848f3299471ea93089bac2e0a9f773faf4ee8fd43f77855933d2":[2,0,3,2,2],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a75bb94f03973a939835d98e9b1999aae":[2,0,3,1,3],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a75bb94f03973a939835d98e9b1999aae":[4,0,0,17,1,3],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a760e5ca8afcbee9f43a72cfd09b7c54e":[2,0,3,1,2],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a760e5ca8afcbee9f43a72cfd09b7c54e":[4,0,0,17,1,2],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a7fd70c48647a2edc5167bce3ade8f2f0":[4,0,0,17,1,1],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a7fd70c48647a2edc5167bce3ade8f2f0":[2,0,3,1,1],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7accee852b0d609496d88d91d683784216":[2,0,3,1,0],
-"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7accee852b0d609496d88d91d683784216":[4,0,0,17,1,0],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a02ac8e7dfc45bb4ae66e97624adaca01":[2,0,3,3,1],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a02ac8e7dfc45bb4ae66e97624adaca01":[4,0,0,17,3,1],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a188731d2f46e10273d74ae7cedbd5bb5":[4,0,0,17,3,2],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a188731d2f46e10273d74ae7cedbd5bb5":[2,0,3,3,2],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a52bf932997783f578fd29c0a4659c556":[2,0,3,3,3],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a52bf932997783f578fd29c0a4659c556":[4,0,0,17,3,3],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0ad559c0f96078b8b7d8b84b77354b2391":[4,0,0,17,3,0],
-"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0ad559c0f96078b8b7d8b84b77354b2391":[2,0,3,3,0],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac":[2,0,3,4,0],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac":[4,0,0,17,4,0],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a914fec87d6b3211d5f2eeb780819e523":[2,0,3,4,1],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a914fec87d6b3211d5f2eeb780819e523":[4,0,0,17,4,1],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92":[4,0,0,17,4,2],
-"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92":[2,0,3,4,2],
-"group__transport.html":[2,0,8],
-"group__transport.html#ga000b2b9ab82139defb1a103f220ec58e":[4,0,0,18,22],
-"group__transport.html#ga000b2b9ab82139defb1a103f220ec58e":[2,0,8,23],
-"group__transport.html#ga09a0d15514ca9a14eb40f12425a52797":[2,0,8,47],
-"group__transport.html#ga09a0d15514ca9a14eb40f12425a52797":[4,0,0,18,46],
-"group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9":[2,0,8,54],
-"group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9":[4,0,0,18,53],
-"group__transport.html#ga1a769e2e6c900c78c710407296cb4e13":[4,0,0,18,17],
-"group__transport.html#ga1a769e2e6c900c78c710407296cb4e13":[2,0,8,18],
-"group__transport.html#ga1f52a6f11322873e74b9daf004269a91":[4,0,0,18,42],
-"group__transport.html#ga1f52a6f11322873e74b9daf004269a91":[2,0,8,43],
-"group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84":[4,0,0,18,27],
-"group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84":[2,0,8,28],
-"group__transport.html#ga285b4cced59c665ae178adf26128d3fc":[2,0,8,12],
-"group__transport.html#ga285b4cced59c665ae178adf26128d3fc":[4,0,0,18,11],
-"group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50":[4,0,0,18,18],
-"group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50":[2,0,8,19],
-"group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf":[2,0,8,57],
-"group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf":[4,0,0,18,56],
-"group__transport.html#ga30d129d04a387ea34515c1641b83521b":[4,0,0,18,21],
-"group__transport.html#ga30d129d04a387ea34515c1641b83521b":[2,0,8,22],
-"group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9":[2,0,8,48],
-"group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9":[4,0,0,18,47],
-"group__transport.html#ga351823e18e043576078f361d7dfe1cce":[4,0,0,18,33],
-"group__transport.html#ga351823e18e043576078f361d7dfe1cce":[2,0,8,34],
-"group__transport.html#ga3887e8d8c60d06df9978947edaf4d461":[2,0,8,55],
-"group__transport.html#ga3887e8d8c60d06df9978947edaf4d461":[4,0,0,18,54],
-"group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688":[4,0,0,18,4],
-"group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688":[2,0,8,4],
-"group__transport.html#ga3eb018b426d168de8c8d9b3441be036c":[4,0,0,18,50],
-"group__transport.html#ga3eb018b426d168de8c8d9b3441be036c":[2,0,8,51],
-"group__transport.html#ga3ef8b0032b2a012c697e853e363338ea":[4,0,0,18,45],
-"group__transport.html#ga3ef8b0032b2a012c697e853e363338ea":[2,0,8,46],
-"group__transport.html#ga46552ed46e59de6530d2eee03707a51b":[4,0,0,18,31],
-"group__transport.html#ga46552ed46e59de6530d2eee03707a51b":[2,0,8,32]
+"group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c":[5,0,0,17,7],
+"group__proactor.html#gade60ff2292b74841766f953b906285c0":[5,0,0,19,10],
+"group__proactor.html#gade60ff2292b74841766f953b906285c0":[3,3,0,23],
+"group__proactor.html#gaf67a7642c9003b36255b58776b494c96":[3,3,0,14],
+"group__proactor.html#gaf67a7642c9003b36255b58776b494c96":[5,0,0,19,1],
+"group__proactor__events.html":[3,3,1],
+"group__sasl.html":[3,0,9],
+"group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283":[3,0,9,4],
+"group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283":[5,0,0,22,4],
+"group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6":[5,0,0,22,5],
+"group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6":[3,0,9,5],
+"group__sasl.html#ga1737191972d5dded0993bf1431e71df0":[3,0,9,3],
+"group__sasl.html#ga1737191972d5dded0993bf1431e71df0":[5,0,0,22,3],
+"group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0":[3,0,9,0],
+"group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0":[5,0,0,22,0],
+"group__sasl.html#ga700e1d505068f895383dd932af55987e":[5,0,0,22,6],
+"group__sasl.html#ga700e1d505068f895383dd932af55987e":[3,0,9,6],
+"group__sasl.html#ga73299a6a22e141e7911a739590032625":[5,0,0,22,8],
+"group__sasl.html#ga73299a6a22e141e7911a739590032625":[3,0,9,8],
+"group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c":[5,0,0,22,2],
+"group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c":[3,0,9,2],
+"group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863":[5,0,0,22,7],
+"group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863":[3,0,9,7],
+"group__sasl.html#gabf4176414424ce02a4e03b4338d30521":[3,0,9,12],
+"group__sasl.html#gabf4176414424ce02a4e03b4338d30521":[5,0,0,22,12],
+"group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243":[3,0,9,10],
+"group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243":[5,0,0,22,10],
+"group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56":[5,0,0,22,11],
+"group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56":[3,0,9,11],
+"group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b":[5,0,0,22,1],
+"group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b":[3,0,9,1],
+"group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315":[3,0,9,9],
+"group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315":[5,0,0,22,9],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e":[3,0,9,1,0],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e":[5,0,0,22,1,1],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191":[5,0,0,22,1,4],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191":[3,0,9,1,3],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba1c90ef54986e694f0d94036977681785":[5,0,0,22,1,0],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a":[5,0,0,22,1,2],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a":[3,0,9,1,1],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939":[5,0,0,22,1,3],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939":[3,0,9,1,2],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3":[5,0,0,22,1,5],
+"group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3":[3,0,9,1,4],
+"group__session.html":[3,0,1],
+"group__session.html#ga0128a4413f413569b91e2bc78217728a":[3,0,1,5],
+"group__session.html#ga0128a4413f413569b91e2bc78217728a":[5,0,0,24,4],
+"group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532":[3,0,1,3],
+"group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532":[5,0,0,24,2],
+"group__session.html#ga0f95b5177494a68991d75444c2f6f812":[3,0,1,2],
+"group__session.html#ga0f95b5177494a68991d75444c2f6f812":[5,0,0,24,1],
+"group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5":[3,0,1,12],
+"group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5":[5,0,0,24,11],
+"group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde":[5,0,0,24,6],
+"group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde":[3,0,1,7],
+"group__session.html#ga1fdeb3d6606e869790a228d847136cb0":[3,0,1,13],
+"group__session.html#ga1fdeb3d6606e869790a228d847136cb0":[5,0,0,24,12],
+"group__session.html#ga1feff407b8fe308a14f283d193246f3c":[3,0,1,1],
+"group__session.html#ga1feff407b8fe308a14f283d193246f3c":[5,0,0,24,0],
+"group__session.html#ga238754f924f84597056f3249a7e7a35f":[3,0,1,20],
+"group__session.html#ga238754f924f84597056f3249a7e7a35f":[5,0,0,24,19],
+"group__session.html#ga2b345eada2c15249caaefaa894d1aae3":[5,0,0,24,10],
+"group__session.html#ga2b345eada2c15249caaefaa894d1aae3":[3,0,1,11],
+"group__session.html#ga31f2e4cc76135f79e96453aa72d441b2":[5,0,0,24,3],
+"group__session.html#ga31f2e4cc76135f79e96453aa72d441b2":[3,0,1,4],
+"group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9":[5,0,0,29,12],
+"group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9":[3,0,1,0],
+"group__session.html#ga55a8429e178831556844ab251ef67c77":[3,0,1,18],
+"group__session.html#ga55a8429e178831556844ab251ef67c77":[5,0,0,24,17],
+"group__session.html#ga577d6f6659958c5d89cd56e944fbd999":[3,0,1,19],
+"group__session.html#ga577d6f6659958c5d89cd56e944fbd999":[5,0,0,24,18],
+"group__session.html#ga7e2a4567e3488a225257e4d883a7e78f":[5,0,0,24,5],
+"group__session.html#ga7e2a4567e3488a225257e4d883a7e78f":[3,0,1,6],
+"group__session.html#ga931b89bd737ab293056cb695dddd9800":[3,0,1,15],
+"group__session.html#ga931b89bd737ab293056cb695dddd9800":[5,0,0,24,14],
+"group__session.html#gaa45a8aa758334528a86cb7914ebe8545":[5,0,0,24,9],
+"group__session.html#gaa45a8aa758334528a86cb7914ebe8545":[3,0,1,10],
+"group__session.html#gabcae388cdcb33e976b490525ec600b50":[3,0,1,17],
+"group__session.html#gabcae388cdcb33e976b490525ec600b50":[5,0,0,24,16],
+"group__session.html#gaca5962e539688b4f31b5b91136aa3c79":[5,0,0,24,15],
+"group__session.html#gaca5962e539688b4f31b5b91136aa3c79":[3,0,1,16],
+"group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece":[3,0,1,9],
+"group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece":[5,0,0,24,8],
+"group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9":[3,0,1,14],
+"group__session.html#gaedc306d86e778cbf8eaaf528c3eacae9":[5,0,0,24,13],
+"group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3":[3,0,1,8],
+"group__session.html#gafdb7b3d530adaaf30aecc73ca6319cf3":[5,0,0,24,7],
+"group__ssl.html":[3,0,10],
+"group__ssl.html#ga03e8070271747c3901d8d6e5710c0066":[5,0,0,25,20],
+"group__ssl.html#ga03e8070271747c3901d8d6e5710c0066":[3,0,10,20],
+"group__ssl.html#ga0c9e8827536b9929793045771d82bdf1":[5,0,0,25,26],
+"group__ssl.html#ga0c9e8827536b9929793045771d82bdf1":[3,0,10,26],
+"group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225":[5,0,0,25,2],
+"group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225":[3,0,10,2],
+"group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3":[3,0,10,24],
+"group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3":[5,0,0,25,24],
+"group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a":[5,0,0,25,22],
+"group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a":[3,0,10,22],
+"group__ssl.html#ga215da63662423b00d34605ba4f9761f5":[5,0,0,25,1],
+"group__ssl.html#ga215da63662423b00d34605ba4f9761f5":[3,0,10,1],
+"group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74":[3,0,10,15],
+"group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74":[5,0,0,25,15],
+"group__ssl.html#ga324db5da83b1abad2e948481d65119d4":[5,0,0,25,25],
+"group__ssl.html#ga324db5da83b1abad2e948481d65119d4":[3,0,10,25],
+"group__ssl.html#ga333fcb941ed20421373f37b23d84fc98":[5,0,0,25,13],
+"group__ssl.html#ga333fcb941ed20421373f37b23d84fc98":[3,0,10,13],
+"group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11":[3,0,10,12],
+"group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11":[5,0,0,25,12],
+"group__ssl.html#ga45f319dd31ad456b8a85927888f94acf":[5,0,0,25,17],
+"group__ssl.html#ga45f319dd31ad456b8a85927888f94acf":[3,0,10,17],
+"group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52":[5,0,0,25,18],
+"group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52":[3,0,10,18],
+"group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d":[3,0,10,9],
+"group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d":[5,0,0,25,9],
+"group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f":[3,0,10,21],
+"group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f":[5,0,0,25,21],
+"group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40":[5,0,0,25,5],
+"group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40":[3,0,10,5],
+"group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d":[5,0,0,25,11],
+"group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d":[3,0,10,11],
+"group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa":[3,0,10,10],
+"group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa":[5,0,0,25,10],
+"group__ssl.html#ga76636a5ce4696284356321226ee0731c":[5,0,0,25,23],
+"group__ssl.html#ga76636a5ce4696284356321226ee0731c":[3,0,10,23],
+"group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d":[3,0,10,19],
+"group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d":[5,0,0,25,19],
+"group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357":[5,0,0,25,8],
+"group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357":[3,0,10,8],
+"group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c":[5,0,0,25,16],
+"group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c":[3,0,10,16],
+"group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175":[3,0,10,0],
+"group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175":[5,0,0,25,0],
+"group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc":[5,0,0,25,14],
+"group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc":[3,0,10,14],
+"group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb":[5,0,0,25,4],
+"group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb":[3,0,10,4],
+"group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb":[3,0,10,7],
+"group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb":[5,0,0,25,7],
+"group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892":[3,0,10,6],
+"group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892":[5,0,0,25,6],
+"group__ssl.html#gaf175c116d52a91001f9a3559b580f56d":[3,0,10,3],
+"group__ssl.html#gaf175c116d52a91001f9a3559b580f56d":[5,0,0,25,3],
+"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078":[5,0,0,25,2,1],
+"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078":[3,0,10,2,1],
+"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c":[5,0,0,25,2,0],
+"group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c":[3,0,10,2,0],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a0eb5c598625be198fe7220e7f8bc5e18":[5,0,0,25,5,2],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a2161af8cc70236ebe4635ef6a3002649":[5,0,0,25,5,4],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40a641ed18c339dabbb246b88b3ed6ecda0":[5,0,0,25,5,3],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40ad39c582ed1f0d3a1f97c17b9432028d6":[5,0,0,25,5,5],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40aeab893d2607ef1ab90e89ba42df33e71":[5,0,0,25,5,1],
+"group__ssl.html#gga68d52866e8172acc7ecc7b4fe5b38a40af5c1deffedaaae563e493e23e7658aa0":[5,0,0,25,5,0],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36":[3,0,10,4,3],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36":[5,0,0,25,4,3],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44":[5,0,0,25,4,1],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44":[3,0,10,4,1],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc":[5,0,0,25,4,0],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc":[3,0,10,4,0],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5":[3,0,10,4,2],
+"group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5":[5,0,0,25,4,2],
+"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a623d60f90b7f0e636db7228e244f2ca0":[5,0,0,25,6,1],
+"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a6c5d0f29a3e5a728a9c80a10f25ac62f":[5,0,0,25,6,3],
+"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892a9449a5575bf4589d1e88687a3a99748b":[5,0,0,25,6,2],
+"group__ssl.html#ggaf0b0cd3271ad4a0e33e2a61a8cea7892add60b6e2931ac8c35d6925e096fb3bf4":[5,0,0,25,6,0],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d":[5,0,0,25,3,2],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d":[3,0,10,3,2],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f":[5,0,0,25,3,1],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f":[3,0,10,3,1],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d":[3,0,10,3,0],
+"group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d":[5,0,0,25,3,0],
+"group__terminus.html":[3,0,3],
+"group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1":[5,0,0,26,8],
+"group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1":[3,0,3,8],
+"group__terminus.html#ga0f9df2253065f81fd304f39a846e6468":[5,0,0,26,13],
+"group__terminus.html#ga0f9df2253065f81fd304f39a846e6468":[3,0,3,13],
+"group__terminus.html#ga213267363be45848f3299471ea93089b":[3,0,3,2],
+"group__terminus.html#ga213267363be45848f3299471ea93089b":[5,0,0,26,2],
+"group__terminus.html#ga2461341ae0d8c2261277837e6e20d2de":[3,0,3,5],
+"group__terminus.html#ga2461341ae0d8c2261277837e6e20d2de":[5,0,0,26,5],
+"group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a":[5,0,0,26,7],
+"group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a":[3,0,3,7],
+"group__terminus.html#ga35d4ced3a1e9056c50adf3a6e051e0d8":[3,0,3,21],
+"group__terminus.html#ga35d4ced3a1e9056c50adf3a6e051e0d8":[5,0,0,26,21],
+"group__terminus.html#ga3cb9c86d1e2bb024de2658f9def098e7":[3,0,3,1],
+"group__terminus.html#ga3cb9c86d1e2bb024de2658f9def098e7":[5,0,0,26,1],
+"group__terminus.html#ga5cc480060f3fda737a333ac7a2ea0d70":[3,0,3,20],
+"group__terminus.html#ga5cc480060f3fda737a333ac7a2ea0d70":[5,0,0,26,20],
+"group__terminus.html#ga5edfc0f1d61880e1951c21f92c19af53":[3,0,3,9],
+"group__terminus.html#ga5edfc0f1d61880e1951c21f92c19af53":[5,0,0,26,9],
+"group__terminus.html#ga62ba74b0c8fad5417a62cffe53996690":[5,0,0,26,15],
+"group__terminus.html#ga62ba74b0c8fad5417a62cffe53996690":[3,0,3,15],
+"group__terminus.html#ga7779782e173db3efcd5de211e0f935ae":[5,0,0,26,18],
+"group__terminus.html#ga7779782e173db3efcd5de211e0f935ae":[3,0,3,18],
+"group__terminus.html#ga822fceb77515b691a10bf5381e4562ec":[3,0,3,6],
+"group__terminus.html#ga822fceb77515b691a10bf5381e4562ec":[5,0,0,26,6],
+"group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d":[3,0,3,16],
+"group__terminus.html#ga8b6c30afc3aa73aac6fc30875fbc386d":[5,0,0,26,16],
+"group__terminus.html#gaa1ad0b04b1625ac1ba5993b6679dcfcf":[5,0,0,26,23],
+"group__terminus.html#gaa1ad0b04b1625ac1ba5993b6679dcfcf":[3,0,3,23],
+"group__terminus.html#gaaad123d27d82b2f7d051489a8bff73c6":[3,0,3,14],
+"group__terminus.html#gaaad123d27d82b2f7d051489a8bff73c6":[5,0,0,26,14],
+"group__terminus.html#gaabb94d82847495c909aab24365d048c6":[3,0,3,10],
+"group__terminus.html#gaabb94d82847495c909aab24365d048c6":[5,0,0,26,10],
+"group__terminus.html#gab4089b27ee99a348deab776f3d4931f0":[5,0,0,26,3],
+"group__terminus.html#gab4089b27ee99a348deab776f3d4931f0":[3,0,3,3],
+"group__terminus.html#gac5e15021927b18d0aa3fd712e4b0ac73":[5,0,0,26,12],
+"group__terminus.html#gac5e15021927b18d0aa3fd712e4b0ac73":[3,0,3,12],
+"group__terminus.html#gac6fb89a5fa96476db51b60f10dc785d0":[3,0,3,4],
+"group__terminus.html#gac6fb89a5fa96476db51b60f10dc785d0":[5,0,0,26,4],
+"group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2":[3,0,3,0],
+"group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2":[5,0,0,26,0],
+"group__terminus.html#gad9f06855cd6538f672c63836b8ef0ae5":[5,0,0,26,11],
+"group__terminus.html#gad9f06855cd6538f672c63836b8ef0ae5":[3,0,3,11],
+"group__terminus.html#gae9c9515f94353eb82cb421e46ce4bb24":[5,0,0,26,19],
+"group__terminus.html#gae9c9515f94353eb82cb421e46ce4bb24":[3,0,3,19],
+"group__terminus.html#gaf9d4257ba00d3e0e0f8d983324018209":[3,0,3,17],
+"group__terminus.html#gaf9d4257ba00d3e0e0f8d983324018209":[5,0,0,26,17],
+"group__terminus.html#gafb9c4b3d344dd94ae174ecd8d25f503c":[5,0,0,26,22],
+"group__terminus.html#gafb9c4b3d344dd94ae174ecd8d25f503c":[3,0,3,22],
+"group__terminus.html#gga213267363be45848f3299471ea93089ba403e259f8d858d6a12f463dbd7e5dc6b":[3,0,3,2,0],
+"group__terminus.html#gga213267363be45848f3299471ea93089ba403e259f8d858d6a12f463dbd7e5dc6b":[5,0,0,26,2,0],
+"group__terminus.html#gga213267363be45848f3299471ea93089ba95b1d5b60c47569e0358258305de1d58":[5,0,0,26,2,1],
+"group__terminus.html#gga213267363be45848f3299471ea93089ba95b1d5b60c47569e0358258305de1d58":[3,0,3,2,1],
+"group__terminus.html#gga213267363be45848f3299471ea93089bac2e0a9f773faf4ee8fd43f77855933d2":[5,0,0,26,2,2],
+"group__terminus.html#gga213267363be45848f3299471ea93089bac2e0a9f773faf4ee8fd43f77855933d2":[3,0,3,2,2],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a75bb94f03973a939835d98e9b1999aae":[5,0,0,26,1,3],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a75bb94f03973a939835d98e9b1999aae":[3,0,3,1,3],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a760e5ca8afcbee9f43a72cfd09b7c54e":[5,0,0,26,1,2],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a760e5ca8afcbee9f43a72cfd09b7c54e":[3,0,3,1,2],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a7fd70c48647a2edc5167bce3ade8f2f0":[3,0,3,1,1],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a7fd70c48647a2edc5167bce3ade8f2f0":[5,0,0,26,1,1],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7accee852b0d609496d88d91d683784216":[3,0,3,1,0],
+"group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7accee852b0d609496d88d91d683784216":[5,0,0,26,1,0],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a02ac8e7dfc45bb4ae66e97624adaca01":[3,0,3,3,1],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a02ac8e7dfc45bb4ae66e97624adaca01":[5,0,0,26,3,1],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a188731d2f46e10273d74ae7cedbd5bb5":[5,0,0,26,3,2],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a188731d2f46e10273d74ae7cedbd5bb5":[3,0,3,3,2],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a52bf932997783f578fd29c0a4659c556":[3,0,3,3,3],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0a52bf932997783f578fd29c0a4659c556":[5,0,0,26,3,3],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0ad559c0f96078b8b7d8b84b77354b2391":[5,0,0,26,3,0],
+"group__terminus.html#ggab4089b27ee99a348deab776f3d4931f0ad559c0f96078b8b7d8b84b77354b2391":[3,0,3,3,0],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac":[3,0,3,4,0],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac":[5,0,0,26,4,0],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a914fec87d6b3211d5f2eeb780819e523":[5,0,0,26,4,1],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a914fec87d6b3211d5f2eeb780819e523":[3,0,3,4,1],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92":[5,0,0,26,4,2],
+"group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92":[3,0,3,4,2],
+"group__transport.html":[3,0,8],
+"group__transport.html#ga000b2b9ab82139defb1a103f220ec58e":[5,0,0,27,22],
+"group__transport.html#ga000b2b9ab82139defb1a103f220ec58e":[3,0,8,23]
 };


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


[17/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.html
index 5f9b77e..b93c0cc 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.html
@@ -109,9 +109,23 @@ Public Member Functions</h2></td></tr>
 &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814">listener</a> ()</td></tr>
 <tr class="memdesc:a59dc4506a73a3d4ae084b5fc1d014814"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create an empty listener. <br /></td></tr>
 <tr class="separator:a59dc4506a73a3d4ae084b5fc1d014814"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a3edec85cbcde06b471e8e2fb4726dbf5"><td class="memItemLeft" align="right" valign="top"><a id="a3edec85cbcde06b471e8e2fb4726dbf5"></a>
+&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a3edec85cbcde06b471e8e2fb4726dbf5">listener</a> (const <a class="el" href="classproton_1_1listener.html">listener</a> &amp;)</td></tr>
+<tr class="memdesc:a3edec85cbcde06b471e8e2fb4726dbf5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy a listener. <br /></td></tr>
+<tr class="separator:a3edec85cbcde06b471e8e2fb4726dbf5"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a426fa804e3bb58ef90b29b066c3f5199"><td class="memItemLeft" align="right" valign="top"><a id="a426fa804e3bb58ef90b29b066c3f5199"></a>
+<a class="el" href="classproton_1_1listener.html">listener</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a426fa804e3bb58ef90b29b066c3f5199">operator=</a> (const <a class="el" href="classproton_1_1listener.html">listener</a> &amp;)</td></tr>
+<tr class="memdesc:a426fa804e3bb58ef90b29b066c3f5199"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy a listener. <br /></td></tr>
+<tr class="separator:a426fa804e3bb58ef90b29b066c3f5199"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a8c528baf37154d347366083f0f816846"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a> ()</td></tr>
 <tr class="memdesc:a8c528baf37154d347366083f0f816846"><td class="mdescLeft">&#160;</td><td class="mdescRight">Stop listening on the address provided to the call to <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">container::listen</a> that returned this listener.  <a href="#a8c528baf37154d347366083f0f816846">More...</a><br /></td></tr>
 <tr class="separator:a8c528baf37154d347366083f0f816846"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a0a3b88007d7cb5fa8d890376c5a8b102"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">port</a> ()</td></tr>
+<tr class="memdesc:a0a3b88007d7cb5fa8d890376c5a8b102"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettedled API</b>  <a href="#a0a3b88007d7cb5fa8d890376c5a8b102">More...</a><br /></td></tr>
+<tr class="separator:a0a3b88007d7cb5fa8d890376c5a8b102"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a2f632b80247e868b8264b8a025b84baf"><td class="memItemLeft" align="right" valign="top">class <a class="el" href="classproton_1_1container.html">container</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listener.html#a2f632b80247e868b8264b8a025b84baf">container</a> () const</td></tr>
+<tr class="memdesc:a2f632b80247e868b8264b8a025b84baf"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettedled API</b>  <a href="#a2f632b80247e868b8264b8a025b84baf">More...</a><br /></td></tr>
+<tr class="separator:a2f632b80247e868b8264b8a025b84baf"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="friends"></a>
 Friends</h2></td></tr>
@@ -121,7 +135,7 @@ class&#160;</td><td class="memItemRight" valign="bottom"><b>container</b></td></
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A listener for incoming connections. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a30">broker.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a1">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a1">direct_send.cpp</a>, and <a class="el" href="helloworld_direct_8cpp-example.html#_a1">helloworld_direct.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a36">broker.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a2">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a2">direct_send.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#_a2">server_direct.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a8c528baf37154d347366083f0f816846"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a8c528baf37154d347366083f0f816846">&#9670;&nbsp;</a></span>stop()</h2>
@@ -139,10 +153,61 @@ class&#160;</td><td class="memItemRight" valign="bottom"><b>container</b></td></
 </div><div class="memdoc">
 
 <p>Stop listening on the address provided to the call to <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">container::listen</a> that returned this listener. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a14">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a16">direct_send.cpp</a>, and <a class="el" href="helloworld_direct_8cpp-example.html#a14">helloworld_direct.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a14">direct_recv.cpp</a>, and <a class="el" href="direct_send_8cpp-example.html#a15">direct_send.cpp</a>.</dd>
 </dl>
 </div>
 </div>
+<a id="a0a3b88007d7cb5fa8d890376c5a8b102"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a0a3b88007d7cb5fa8d890376c5a8b102">&#9670;&nbsp;</a></span>port()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">int port </td>
+          <td>(</td>
+          <td class="paramname"></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p><b>Unsettedled API</b> </p>
+<p>Return the port used by the listener. If port 0 was passed to <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">container::listen</a>, this will be a dynamically allocated port. </p><dl class="exception"><dt>Exceptions</dt><dd>
+  <table class="exception">
+    <tr><td class="paramname"><a class="el" href="structproton_1_1error.html" title="The base Proton error. ">proton::error</a></td><td>if the listener does not have a port </td></tr>
+  </table>
+  </dd>
+</dl>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a38">broker.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a3">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a3">direct_send.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#a3">server_direct.cpp</a>.</dd>
+</dl>
+</div>
+</div>
+<a id="a2f632b80247e868b8264b8a025b84baf"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a2f632b80247e868b8264b8a025b84baf">&#9670;&nbsp;</a></span>container()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname">class <a class="el" href="classproton_1_1container.html">container</a>&amp; <a class="el" href="classproton_1_1container.html">container</a> </td>
+          <td>(</td>
+          <td class="paramname"></td><td>)</td>
+          <td> const</td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p><b>Unsettedled API</b> </p>
+<p>Get the container. </p><dl class="exception"><dt>Exceptions</dt><dd>
+  <table class="exception">
+    <tr><td class="paramname"><a class="el" href="structproton_1_1error.html" title="The base Proton error. ">proton::error</a></td><td>if this listener is not managed by a container. </td></tr>
+  </table>
+  </dd>
+</dl>
+
+</div>
+</div>
 <hr/>The documentation for this class was generated from the following file:<ul>
 <li>proton/<a class="el" href="listener_8hpp_source.html">listener.hpp</a></li>
 </ul>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.js
index 1360204..1df8ebc 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener.js
@@ -1,6 +1,11 @@
 var classproton_1_1listener =
 [
     [ "listener", "classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814", null ],
+    [ "listener", "classproton_1_1listener.html#a3edec85cbcde06b471e8e2fb4726dbf5", null ],
+    [ "~listener", "classproton_1_1listener.html#a9caf6e5d845d981780d2e7fde8795999", null ],
+    [ "operator=", "classproton_1_1listener.html#a426fa804e3bb58ef90b29b066c3f5199", null ],
     [ "stop", "classproton_1_1listener.html#a8c528baf37154d347366083f0f816846", null ],
+    [ "port", "classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102", null ],
+    [ "container", "classproton_1_1listener.html#a2f632b80247e868b8264b8a025b84baf", null ],
     [ "container", "classproton_1_1listener.html#aa8f995c5381203abbca1b92a9a097697", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message-members.html
index 1ed5a12..8ae52c8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message-members.html
@@ -111,8 +111,8 @@ $(document).ready(function(){initNavTree('classproton_1_1message.html','');});
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">creation_time</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#a53538e1ae48ba56e7285ca859d9cee50">decode</a>(const std::vector&lt; char &gt; &amp;)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">default_priority</a></td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>delivery_annotations</b>() (defined in <a class="el" href="classproton_1_1message.html">message</a>)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>delivery_annotations</b>() const (defined in <a class="el" href="classproton_1_1message.html">message</a>)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">delivery_annotations</a>()</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#a61a343c78248490a76ea6999e8fccb65">delivery_annotations</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">delivery_count</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#aaaf044a6b10403eafed371d20d5ba5c1">delivery_count</a>(uint32_t)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">durable</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
@@ -135,8 +135,8 @@ $(document).ready(function(){initNavTree('classproton_1_1message.html','');});
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#a583555130839030cf9aa09d81ff1eb1b">message</a>(const message &amp;)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#ac716863d91640bb061498ed141fdb7e4">message</a>(message &amp;&amp;)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#aa99aeff68b6093da4e3c11ecf898376d">message</a>(const value &amp;x)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>message_annotations</b>() (defined in <a class="el" href="classproton_1_1message.html">message</a>)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>message_annotations</b>() const (defined in <a class="el" href="classproton_1_1message.html">message</a>)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1message.html#a5d96699458d8be84d821f5651a7b3717">message_annotations</a>()</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#a05ea365ef83130c85ffbb74498955ca3">message_annotations</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">operator=</a>(const message &amp;)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1message.html#ac7abf26f9566b75b59af27ca13b2182f">operator=</a>(message &amp;&amp;)</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">priority</a>() const</td><td class="entry"><a class="el" href="classproton_1_1message.html">message</a></td><td class="entry"></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message.html
index e098023..9bc0755 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1message.html
@@ -106,11 +106,13 @@ $(document).ready(function(){initNavTree('classproton_1_1message.html','');});
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-types"></a>
 Public Types</h2></td></tr>
-<tr class="memitem:a071e4357cc12168d97a7251b5a5b9784"><td class="memItemLeft" align="right" valign="top">typedef <a class="el" href="classproton_1_1map.html">map</a>&lt; std::string, <a class="el" href="classproton_1_1scalar.html">scalar</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">property_map</a></td></tr>
-<tr class="memdesc:a071e4357cc12168d97a7251b5a5b9784"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - A map of string keys and AMQP scalar values.  <a href="#a071e4357cc12168d97a7251b5a5b9784">More...</a><br /></td></tr>
+<tr class="memitem:a071e4357cc12168d97a7251b5a5b9784"><td class="memItemLeft" align="right" valign="top"><a id="a071e4357cc12168d97a7251b5a5b9784"></a>
+typedef <a class="el" href="classproton_1_1map.html">map</a>&lt; std::string, <a class="el" href="classproton_1_1scalar.html">scalar</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">property_map</a></td></tr>
+<tr class="memdesc:a071e4357cc12168d97a7251b5a5b9784"><td class="mdescLeft">&#160;</td><td class="mdescRight">A map of string keys and AMQP scalar values. <br /></td></tr>
 <tr class="separator:a071e4357cc12168d97a7251b5a5b9784"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a3c6892bfc5d3b4b1972dc23c004929b7"><td class="memItemLeft" align="right" valign="top">typedef <a class="el" href="classproton_1_1map.html">map</a>&lt; <a class="el" href="classproton_1_1annotation__key.html">annotation_key</a>, <a class="el" href="classproton_1_1value.html">value</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a></td></tr>
-<tr class="memdesc:a3c6892bfc5d3b4b1972dc23c004929b7"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - A map of AMQP annotation keys and AMQP values.  <a href="#a3c6892bfc5d3b4b1972dc23c004929b7">More...</a><br /></td></tr>
+<tr class="memitem:a3c6892bfc5d3b4b1972dc23c004929b7"><td class="memItemLeft" align="right" valign="top"><a id="a3c6892bfc5d3b4b1972dc23c004929b7"></a>
+typedef <a class="el" href="classproton_1_1map.html">map</a>&lt; <a class="el" href="classproton_1_1annotation__key.html">annotation_key</a>, <a class="el" href="classproton_1_1value.html">value</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a></td></tr>
+<tr class="memdesc:a3c6892bfc5d3b4b1972dc23c004929b7"><td class="mdescLeft">&#160;</td><td class="mdescRight">A map of AMQP annotation keys and AMQP values. <br /></td></tr>
 <tr class="separator:a3c6892bfc5d3b4b1972dc23c004929b7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
@@ -314,28 +316,27 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a2c47345d04743821765ec83e13396f29">group_sequence</a> (int32_t)</td></tr>
 <tr class="memdesc:a2c47345d04743821765ec83e13396f29"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set the group sequence for a message. <br /></td></tr>
 <tr class="separator:a2c47345d04743821765ec83e13396f29"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr><td colspan="2"><div class="groupHeader">**Unsettled API** - Application properties</div></td></tr>
+<tr><td colspan="2"><div class="groupHeader">Extended attributes</div></td></tr>
 <tr class="memitem:ac163919aa25a6ed5b33a29a96d04e028"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">property_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">properties</a> ()</td></tr>
-<tr class="memdesc:ac163919aa25a6ed5b33a29a96d04e028"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Get the application properties map.  <a href="#ac163919aa25a6ed5b33a29a96d04e028">More...</a><br /></td></tr>
+<tr class="memdesc:ac163919aa25a6ed5b33a29a96d04e028"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the application properties map.  <a href="#ac163919aa25a6ed5b33a29a96d04e028">More...</a><br /></td></tr>
 <tr class="separator:ac163919aa25a6ed5b33a29a96d04e028"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ac7c0f75dbd504b5cde8b586a4005e262"><td class="memItemLeft" align="right" valign="top"><a id="ac7c0f75dbd504b5cde8b586a4005e262"></a>
 const <a class="el" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">property_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#ac7c0f75dbd504b5cde8b586a4005e262">properties</a> () const</td></tr>
-<tr class="memdesc:ac7c0f75dbd504b5cde8b586a4005e262"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - examine the application properties map. <br /></td></tr>
+<tr class="memdesc:ac7c0f75dbd504b5cde8b586a4005e262"><td class="mdescLeft">&#160;</td><td class="mdescRight">Examine the application properties map. <br /></td></tr>
 <tr class="separator:ac7c0f75dbd504b5cde8b586a4005e262"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr><td colspan="2"><div class="groupHeader">**Unsettled API** - Annotations</div></td></tr>
-<tr><td colspan="2"><div class="groupText"><p>Normally used by messaging infrastructure, not applications. </p>
-</div></td></tr>
-<tr class="memitem:a5d96699458d8be84d821f5651a7b3717"><td class="memItemLeft" align="right" valign="top"><a id="a5d96699458d8be84d821f5651a7b3717"></a>
-<a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>message_annotations</b> ()</td></tr>
+<tr class="memitem:a5d96699458d8be84d821f5651a7b3717"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a5d96699458d8be84d821f5651a7b3717">message_annotations</a> ()</td></tr>
+<tr class="memdesc:a5d96699458d8be84d821f5651a7b3717"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the message annotations map.  <a href="#a5d96699458d8be84d821f5651a7b3717">More...</a><br /></td></tr>
 <tr class="separator:a5d96699458d8be84d821f5651a7b3717"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a05ea365ef83130c85ffbb74498955ca3"><td class="memItemLeft" align="right" valign="top"><a id="a05ea365ef83130c85ffbb74498955ca3"></a>
-const <a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>message_annotations</b> () const</td></tr>
+const <a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a05ea365ef83130c85ffbb74498955ca3">message_annotations</a> () const</td></tr>
+<tr class="memdesc:a05ea365ef83130c85ffbb74498955ca3"><td class="mdescLeft">&#160;</td><td class="mdescRight">Examine the message annotations map. <br /></td></tr>
 <tr class="separator:a05ea365ef83130c85ffbb74498955ca3"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:adb613430bba5478feb0c458d8a9e7145"><td class="memItemLeft" align="right" valign="top"><a id="adb613430bba5478feb0c458d8a9e7145"></a>
-<a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>delivery_annotations</b> ()</td></tr>
+<tr class="memitem:adb613430bba5478feb0c458d8a9e7145"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">delivery_annotations</a> ()</td></tr>
+<tr class="memdesc:adb613430bba5478feb0c458d8a9e7145"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the delivery annotations map.  <a href="#adb613430bba5478feb0c458d8a9e7145">More...</a><br /></td></tr>
 <tr class="separator:adb613430bba5478feb0c458d8a9e7145"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a61a343c78248490a76ea6999e8fccb65"><td class="memItemLeft" align="right" valign="top"><a id="a61a343c78248490a76ea6999e8fccb65"></a>
-const <a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>delivery_annotations</b> () const</td></tr>
+const <a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1message.html#a61a343c78248490a76ea6999e8fccb65">delivery_annotations</a> () const</td></tr>
+<tr class="memdesc:a61a343c78248490a76ea6999e8fccb65"><td class="mdescLeft">&#160;</td><td class="mdescRight">Examine the delivery annotations map. <br /></td></tr>
 <tr class="separator:a61a343c78248490a76ea6999e8fccb65"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-static-attribs"></a>
@@ -348,41 +349,8 @@ static const uint8_t&#160;</td><td class="memItemRight" valign="bottom"><a class
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>An AMQP message. </p>
 <p>Value semantics: A message can be copied or assigned to make a new message. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a7">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a10">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a7">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a8">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a12">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a8">helloworld_direct.cpp</a>, <a class="el" href="message_properties_8cpp-example.html#_a0">message_properties.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a3">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a6">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a18">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a16">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example
 .html#_a10">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a13">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a19">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a10">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a10">simple_send.cpp</a>.</dd>
-</dl></div><h2 class="groupheader">Member Typedef Documentation</h2>
-<a id="a071e4357cc12168d97a7251b5a5b9784"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a071e4357cc12168d97a7251b5a5b9784">&#9670;&nbsp;</a></span>property_map</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname">typedef <a class="el" href="classproton_1_1map.html">map</a>&lt;std::string, <a class="el" href="classproton_1_1scalar.html">scalar</a>&gt; <a class="el" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">property_map</a></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-<p><b>Unsettled API</b> - A map of string keys and AMQP scalar values. </p>
-
-</div>
-</div>
-<a id="a3c6892bfc5d3b4b1972dc23c004929b7"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a3c6892bfc5d3b4b1972dc23c004929b7">&#9670;&nbsp;</a></span>annotation_map</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname">typedef <a class="el" href="classproton_1_1map.html">map</a>&lt;<a class="el" href="classproton_1_1annotation__key.html">annotation_key</a>, <a class="el" href="classproton_1_1value.html">value</a>&gt; <a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-<p><b>Unsettled API</b> - A map of AMQP annotation keys and AMQP values. </p>
-
-</div>
-</div>
-<h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a7">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a10">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a7">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a8">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a10">helloworld.cpp</a>, <a class="el" href="message_properties_8cpp-example.html#_a0">message_properties.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a3">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a6">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a18">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a16">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#_a8">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a13">ser
 ver_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a22">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a10">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a10">simple_send.cpp</a>.</dd>
+</dl></div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
 <a id="aa99aeff68b6093da4e3c11ecf898376d"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#aa99aeff68b6093da4e3c11ecf898376d">&#9670;&nbsp;</a></span>message()</h2>
 
@@ -602,12 +570,52 @@ static const uint8_t&#160;</td><td class="memItemRight" valign="bottom"><a class
       </table>
 </div><div class="memdoc">
 
-<p><b>Unsettled API</b> - Get the application properties map. </p>
+<p>Get the application properties map. </p>
 <p>It can be modified in place. </p>
 <dl><dt><b>Examples: </b></dt><dd><a class="el" href="message_properties_8cpp-example.html#a1">message_properties.cpp</a>.</dd>
 </dl>
 </div>
 </div>
+<a id="a5d96699458d8be84d821f5651a7b3717"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a5d96699458d8be84d821f5651a7b3717">&#9670;&nbsp;</a></span>message_annotations()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a>&amp; message_annotations </td>
+          <td>(</td>
+          <td class="paramname"></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Get the message annotations map. </p>
+<p>It can be modified in place. </p>
+
+</div>
+</div>
+<a id="adb613430bba5478feb0c458d8a9e7145"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#adb613430bba5478feb0c458d8a9e7145">&#9670;&nbsp;</a></span>delivery_annotations()</h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname"><a class="el" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a>&amp; delivery_annotations </td>
+          <td>(</td>
+          <td class="paramname"></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Get the delivery annotations map. </p>
+<p>It can be modified in place. </p>
+
+</div>
+</div>
 <hr/>The documentation for this class was generated from the following file:<ul>
 <li>proton/<a class="el" href="message_8hpp_source.html">message.hpp</a></li>
 </ul>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler-members.html
index 298aff5..9a245f1 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler-members.html
@@ -97,36 +97,36 @@ $(document).ready(function(){initNavTree('classproton_1_1messaging__handler.html
 <p>This is the complete list of members for <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a>, including all inherited members.</p>
 <table class="directory">
   <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>messaging_handler</b>() (defined in <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a>)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a804f0ea9c2754f143624b4078a61f650">on_connection_close</a>(connection &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aafa83dc2f8f477ba1f76e86dc69cd1e9">on_connection_error</a>(connection &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">on_connection_open</a>(connection &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a8368c2f41b5c1dab4aa063c1c78a6e19">on_connection_close</a>(connection &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ae93110a9bad4868663f37d15cd3139a4">on_connection_error</a>(connection &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">on_connection_open</a>(connection &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481">on_connection_wake</a>(connection &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a>(container &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ab5bb8195e26c8818c4f57a734566ecfd">on_container_stop</a>(container &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#afc96eabc76c471d61627493eadb58ac8">on_delivery_settle</a>(delivery &amp;d)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">on_error</a>(const error_condition &amp;c)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a>(delivery &amp;d, message &amp;m)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907">on_receiver_close</a>(receiver &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a93ab65773954cf12eb7f76a26aa44cfe">on_receiver_detach</a>(receiver &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a815e30c6d10d923d88dc1085b7b0f116">on_receiver_drain_finish</a>(receiver &amp;r)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a0c281aee5483822bdf4b428834bd7f28">on_receiver_error</a>(receiver &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd">on_receiver_open</a>(receiver &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a>(sender &amp;s)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84">on_sender_close</a>(sender &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a731e7cdbda64b15f069efd560b66ada1">on_sender_detach</a>(sender &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ad3d23a7c3849dabd137610f8ee1569e3">on_sender_drain_start</a>(sender &amp;s)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a2d9d98eee878f1e734457ba01e21228a">on_sender_error</a>(sender &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">on_sender_open</a>(sender &amp;l)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a54fe4fc5394418f8606f9263f13d2e98">on_session_close</a>(session &amp;s)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aca924d2f68649df7945719be3d29a597">on_session_error</a>(session &amp;s)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#adddbfd9b7fc7719490bdc21331c42302">on_session_open</a>(session &amp;s)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad">on_tracker_accept</a>(tracker &amp;d)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a0740e8c9ed9d0c304d2adced09802893">on_tracker_reject</a>(tracker &amp;d)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#acfde5590c6e826ef9e2c33a28edefe19">on_tracker_release</a>(tracker &amp;d)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a023a5c57eeeaf79ed5b768cd172ad0ac">on_tracker_settle</a>(tracker &amp;d)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f">on_transport_close</a>(transport &amp;t)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653">on_transport_error</a>(transport &amp;t)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a0c141065eda9a26916ccc63ccea5d3b7">on_transport_open</a>(transport &amp;t)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">on_container_start</a>(container &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">on_container_stop</a>(container &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a4f0e5cebf65a87f301ba5ef82eb8537d">on_delivery_settle</a>(delivery &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">on_error</a>(const error_condition &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">on_message</a>(delivery &amp;, message &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28">on_receiver_close</a>(receiver &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a06b10fbf8524545eaf88def91d7235ef">on_receiver_detach</a>(receiver &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a0c3ba013a3515fd3d0a1871c984e497e">on_receiver_drain_finish</a>(receiver &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ac0daca9ec2dc45353a04069c6a12f3aa">on_receiver_error</a>(receiver &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401">on_receiver_open</a>(receiver &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">on_sendable</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29">on_sender_close</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ae103f0e8f35a8aebfb14b96c298ed938">on_sender_detach</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ac07a9aab7eee64a7415f1cacc278344b">on_sender_drain_start</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a2347cff02f9ed958ca41fcc31e58d792">on_sender_error</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">on_sender_open</a>(sender &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aa3ff10317b9fdcbe00e500cb1e9c96ec">on_session_close</a>(session &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a63bb630e8dc357b22d6c33781c7c6a11">on_session_error</a>(session &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aad43a0028727310bcdbd8f63feb99537">on_session_open</a>(session &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a4e61812588fe6fbde253b41f7c02e993">on_tracker_accept</a>(tracker &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a116c831b8a80727a451ce20c44d781f8">on_tracker_reject</a>(tracker &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ad107964511dce62449ca730e9b0aca88">on_tracker_release</a>(tracker &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a36620e631024c73f5c6766abf95a8356">on_tracker_settle</a>(tracker &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f">on_transport_close</a>(transport &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665">on_transport_error</a>(transport &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html#aa68ce0021c22cc956890c6bcc5384b84">on_transport_open</a>(transport &amp;)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
   <tr bgcolor="#f0f0f0"><td class="entry"><b>~messaging_handler</b>() (defined in <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a>)</td><td class="entry"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->


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


[38/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/message_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/message_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/message_8h_source.html
index 07dfe4a..4ab4803 100755
--- a/content/releases/qpid-proton-master/proton/c/api/message_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/message_8h_source.html
@@ -93,9 +93,9 @@ $(document).ready(function(){initNavTree('message_8h_source.html','');});
 <div class="title">message.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="message_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGE_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGE_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agr
 eements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class
 ="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span>
 </div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a nam
 e="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="codec_8h.html">proton/codec.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="prepr
 ocessor">#endif</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">   51</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a>;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__message.html#ga732b155202644a5c5be75a651a3c4fac">   56</a></span>&#160;<span class="preprocessor">#define PN_DEFAULT_PRIORITY (4)</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00066"></a><span class="linen
 o">   66</span>&#160;PN_EXTERN <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> * <a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;PN_EXTERN <span class="keywordtype">void</span>           <a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;PN_EXTERN <span class="keywordtype">void</span>           <a class="code" href="group__message.html#ga918c90a049d6b39041b0a2044f9048c6">pn_messa
 ge_clear</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gac10c5d8f12e4817fec126fdb608baf53">pn_message_errno</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a>    *<a class="code" href="group__message.html#ga9ad09178e7682efde76e2d39f352dfe8">pn_message_error</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_mess
 age_t</a> *msg);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>           <a class="code" href="group__message.html#ga5d9367609d74ca3511d4172806eeb55b">pn_message_is_inferred</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga63bdd43b7cee8741665db999fac97a62">pn_message_set_inferred</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> inferred);</div><div class="line"><a name="l00140"></a><span class="lineno">  
 140</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="comment">// standard message headers and properties</span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>           <a class="code" href="group__message.html#gaf9e131dcfb094bebc3424661042d3c36">pn_message_is_durable</a>            (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad">pn_message_set_durable</a>           (<a class="code" href="group__message.html
 #gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> durable);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN uint8_t        <a class="code" href="group__message.html#ga5e6769354fcb71c9053fff0045301a0e">pn_message_get_priority</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c">pn_message_set_priority</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, uint8_t priority);</div><div class="l
 ine"><a name="l00188"></a><span class="lineno">  188</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>    <a class="code" href="group__message.html#ga2ade598da4a8bb0464980ae227f29d5c">pn_message_get_ttl</a>               (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3">pn_message_set_ttl</a>               (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723
 c">pn_millis_t</a> ttl);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>           <a class="code" href="group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2">pn_message_is_first_acquirer</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga64240467da74892010a7282116b0b234">pn_message_set_first_acquirer</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> first);</div><div class="line"><a name="l00239"><
 /a><span class="lineno">  239</span>&#160;</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;PN_EXTERN uint32_t       <a class="code" href="group__message.html#gad514ef95e642698876bedf6ec772eb72">pn_message_get_delivery_count</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0">pn_message_set_delivery_count</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, uint32_t count);</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;PN
 _EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *    <a class="code" href="group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de">pn_message_id</a>                    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>      <a class="code" href="group__message.html#gad7d3aa060b7666dce6a6d955945bedce">pn_message_get_id</a>                (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;</div><div class="line"><a name="l00304"></a><span class="lineno">  304</span>&#160;PN_EXTERN <span class="keywordty
 pe">int</span>            <a class="code" href="group__message.html#gad169c319e27eacf91864da26a23b6d74">pn_message_set_id</a>                (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a> <span class="keywordtype">id</span>);</div><div class="line"><a name="l00305"></a><span class="lineno">  305</span>&#160;</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a>     <a class="code" href="group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c">pn_message_get_user_id</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00320"></a><span class="lineno">  320</span>&#160;</div><div class="line"><a name="l00331"></a><span class="lineno">  331</spa
 n>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga5fc42eff5ec52b83099089f5888be38d">pn_message_set_user_id</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> user_id);</div><div class="line"><a name="l00332"></a><span class="lineno">  332</span>&#160;</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c">pn_message_get_address</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00348"></a><span class="lineno">  348</span>&#160;</div><div class="line"><a name="l00361"></a><span class="lineno">  3
 61</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga38ecee233f94e128bed9be3e530f27e5">pn_message_set_address</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l00362"></a><span class="lineno">  362</span>&#160;</div><div class="line"><a name="l00377"></a><span class="lineno">  377</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c">pn_message_get_subject</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00378"></a><span class="lineno">  378</span>&#160;</div><div class="line"><a name="l00391"></a><span class="lineno">  
 391</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa8594da8507dc031b1e0e89d51a2f281">pn_message_set_subject</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *subject);</div><div class="line"><a name="l00392"></a><span class="lineno">  392</span>&#160;</div><div class="line"><a name="l00407"></a><span class="lineno">  407</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33">pn_message_get_reply_to</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00408"></a><span class="lineno">  408</span>&#160;</div><div class="line"><a name="l00421"></a><span class="lineno"> 
  421</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313">pn_message_set_reply_to</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *reply_to);</div><div class="line"><a name="l00422"></a><span class="lineno">  422</span>&#160;</div><div class="line"><a name="l00435"></a><span class="lineno">  435</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *    <a class="code" href="group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd">pn_message_correlation_id</a>        (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00436"></a><span class="lineno">  436</span>&#160;</div><div class="line"><a name="l00448"></a><sp
 an class="lineno">  448</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>      <a class="code" href="group__message.html#ga7c7a49b84141d130f885e3a6b357d65a">pn_message_get_correlation_id</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00449"></a><span class="lineno">  449</span>&#160;</div><div class="line"><a name="l00461"></a><span class="lineno">  461</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a">pn_message_set_correlation_id</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a> <span class="keywordtype">id</span>);</div><div class="line"><a name="l00462"></a><span class="lineno">  462</span>&#160;</div><di
 v class="line"><a name="l00477"></a><span class="lineno">  477</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga280a96bf80dd37a4062432f45e679ea1">pn_message_get_content_type</a>      (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00478"></a><span class="lineno">  478</span>&#160;</div><div class="line"><a name="l00491"></a><span class="lineno">  491</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa0247560f0cd4590bc8ece20565eb611">pn_message_set_content_type</a>      (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *type);</div><div class="line"><a name="l00492"></a><span class="lineno">  492</span>&#160;</div><div 
 class="line"><a name="l00507"></a><span class="lineno">  507</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gacb97f21822b058b6297bc618f6d190b0">pn_message_get_content_encoding</a>  (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00508"></a><span class="lineno">  508</span>&#160;</div><div class="line"><a name="l00521"></a><span class="lineno">  521</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b">pn_message_set_content_encoding</a>  (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *encoding);</div><div class="line"><a name="l00522"></a><span class="lineno">  522</span>&#160;</div><di
 v class="line"><a name="l00532"></a><span class="lineno">  532</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce">pn_message_get_expiry_time</a>       (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00533"></a><span class="lineno">  533</span>&#160;</div><div class="line"><a name="l00543"></a><span class="lineno">  543</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga6c108bc39b13c5257671aee68ea981c7">pn_message_set_expiry_time</a>       (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> time);</div><div class="line"><a name="l00544"></a
 ><span class="lineno">  544</span>&#160;</div><div class="line"><a name="l00554"></a><span class="lineno">  554</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__message.html#ga4a18377a68cc26d68141e1b1afd82a52">pn_message_get_creation_time</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00555"></a><span class="lineno">  555</span>&#160;</div><div class="line"><a name="l00565"></a><span class="lineno">  565</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2">pn_message_set_creation_time</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> t
 ime);</div><div class="line"><a name="l00566"></a><span class="lineno">  566</span>&#160;</div><div class="line"><a name="l00581"></a><span class="lineno">  581</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b">pn_message_get_group_id</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00582"></a><span class="lineno">  582</span>&#160;</div><div class="line"><a name="l00595"></a><span class="lineno">  595</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc">pn_message_set_group_id</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *gro
 up_id);</div><div class="line"><a name="l00596"></a><span class="lineno">  596</span>&#160;</div><div class="line"><a name="l00607"></a><span class="lineno">  607</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a>  <a class="code" href="group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4">pn_message_get_group_sequence</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00608"></a><span class="lineno">  608</span>&#160;</div><div class="line"><a name="l00619"></a><span class="lineno">  619</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga2b9e17a8c639adba856130ad714ca31a">pn_message_set_group_sequence</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#ga92033
 eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a> n);</div><div class="line"><a name="l00620"></a><span class="lineno">  620</span>&#160;</div><div class="line"><a name="l00635"></a><span class="lineno">  635</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga7163a0174e7c71361172a1f6387f232a">pn_message_get_reply_to_group_id</a> (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00636"></a><span class="lineno">  636</span>&#160;</div><div class="line"><a name="l00649"></a><span class="lineno">  649</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga304bbec66cac6f09f01cbf7014196fd9">pn_message_set_reply_to_group_id</a> (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</spa
 n> <span class="keywordtype">char</span> *reply_to_group_id);</div><div class="line"><a name="l00650"></a><span class="lineno">  650</span>&#160;</div><div class="line"><a name="l00666"></a><span class="lineno">  666</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga02347ad161f972e4b94567f329b53a8a">pn_message_instructions</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00667"></a><span class="lineno">  667</span>&#160;</div><div class="line"><a name="l00682"></a><span class="lineno">  682</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#gadadb16710eccb6d332d039acc9dc1042">pn_message_annotations</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message
 _t</a> *msg);</div><div class="line"><a name="l00683"></a><span class="lineno">  683</span>&#160;</div><div class="line"><a name="l00698"></a><span class="lineno">  698</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00699"></a><span class="lineno">  699</span>&#160;</div><div class="line"><a name="l00711"></a><span class="lineno">  711</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00712"></a
 ><span class="lineno">  712</span>&#160;</div><div class="line"><a name="l00725"></a><span class="lineno">  725</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">pn_message_decode</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00726"></a><span class="lineno">  726</span>&#160;</div><div class="line"><a name="l00740"></a><span class="lineno">  740</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</sp
 an> *size);</div><div class="line"><a name="l00741"></a><span class="lineno">  741</span>&#160;</div><div class="line"><a name="l00745"></a><span class="lineno">  745</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#ga013d429f94d653bc1e00f1f438a079a6">pn_message_data</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data);</div><div class="line"><a name="l00746"></a><span class="lineno">  746</span>&#160;</div><div class="line"><a name="l00750"></a><span class="lineno">  750</span>&#160;PN_EXTERN <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> * pn_message_with_extra(<span class="keywordtype">size_t</span> extra);</div><div class="line"><a name="l00751"></a><span class="lineno">  751</span>&#160;</div><div class="line"><a name="l00753"></a><sp
 an class="lineno">  753</span>&#160;PN_EXTERN <span class="keywordtype">void</span>* pn_message_get_extra(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00754"></a><span class="lineno">  754</span>&#160;</div><div class="line"><a name="l00761"></a><span class="lineno">  761</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00762"></a><span class="lineno">  762</span>&#160;}</div><div class="line"><a name="l00763"></a><span class="lineno">  763</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00764"></a><span class="lineno">  764</span>&#160;</div><div class="line"><a name="l00765"></a><span class="lineno">  765</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* message.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__message_html_ga280a96bf80dd37a4062432f45
 e679ea1"><div class="ttname"><a href="group__message.html#ga280a96bf80dd37a4062432f45e679ea1">pn_message_get_content_type</a></div><div class="ttdeci">const char * pn_message_get_content_type(pn_message_t *msg)</div><div class="ttdoc">Get the content_type for a message. </div></div>
+<a href="message_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGE_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGE_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agr
 eements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class
 ="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span>
 </div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a nam
 e="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="codec_8h.html">proton/codec.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="prepr
 ocessor">#endif</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">   51</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a>;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__message.html#ga732b155202644a5c5be75a651a3c4fac">   56</a></span>&#160;<span class="preprocessor">#define PN_DEFAULT_PRIORITY (4)</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00066"></a><span class="linen
 o">   66</span>&#160;PN_EXTERN <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> * <a class="code" href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;PN_EXTERN <span class="keywordtype">void</span>           <a class="code" href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;PN_EXTERN <span class="keywordtype">void</span>           <a class="code" href="group__message.html#ga918c90a049d6b39041b0a2044f9048c6">pn_messa
 ge_clear</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gac10c5d8f12e4817fec126fdb608baf53">pn_message_errno</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PN_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a>    *<a class="code" href="group__message.html#ga9ad09178e7682efde76e2d39f352dfe8">pn_message_error</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_mess
 age_t</a> *msg);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>           <a class="code" href="group__message.html#ga5d9367609d74ca3511d4172806eeb55b">pn_message_is_inferred</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga63bdd43b7cee8741665db999fac97a62">pn_message_set_inferred</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> inferred);</div><div class="line"><a name="l00140"></a><span class="lineno">  
 140</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>           <a class="code" href="group__message.html#gaf9e131dcfb094bebc3424661042d3c36">pn_message_is_durable</a>            (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad">pn_message_set_durable</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> durable);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00174"></a><sp
 an class="lineno">  174</span>&#160;PN_EXTERN uint8_t        <a class="code" href="group__message.html#ga5e6769354fcb71c9053fff0045301a0e">pn_message_get_priority</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c">pn_message_set_priority</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, uint8_t priority);</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c"
 >pn_millis_t</a>    <a class="code" href="group__message.html#ga2ade598da4a8bb0464980ae227f29d5c">pn_message_get_ttl</a>               (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaf39d162f5ee8f43b32cc7f1ebf56ffa3">pn_message_set_ttl</a>               (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> ttl);</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00224"></a><span class="lineno">  224</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>
            <a class="code" href="group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2">pn_message_is_first_acquirer</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga64240467da74892010a7282116b0b234">pn_message_set_first_acquirer</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">bool</span> first);</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;PN_EXTERN uint32_t       <a class="code" href="group__message.html#gad514ef95e642698876bedf6ec772eb72">pn_message
 _get_delivery_count</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0">pn_message_set_delivery_count</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, uint32_t count);</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *    <a class="code" href="group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de">pn_message_id</a>                    (<a class="code" href=
 "group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;</div><div class="line"><a name="l00289"></a><span class="lineno">  289</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>      <a class="code" href="group__message.html#gad7d3aa060b7666dce6a6d955945bedce">pn_message_get_id</a>                (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;</div><div class="line"><a name="l00302"></a><span class="lineno">  302</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gad169c319e27eacf91864da26a23b6d74">pn_message_set_id</a>                (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *m
 sg, <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a> <span class="keywordtype">id</span>);</div><div class="line"><a name="l00303"></a><span class="lineno">  303</span>&#160;</div><div class="line"><a name="l00317"></a><span class="lineno">  317</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a>     <a class="code" href="group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c">pn_message_get_user_id</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;</div><div class="line"><a name="l00329"></a><span class="lineno">  329</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga5fc42eff5ec52b83099089f5888be38d">pn_message_set_user_id</a>           (<a class="code" href="group__message.html#gad9259fa9271e8
 844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> user_id);</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;</div><div class="line"><a name="l00345"></a><span class="lineno">  345</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c">pn_message_get_address</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00346"></a><span class="lineno">  346</span>&#160;</div><div class="line"><a name="l00359"></a><span class="lineno">  359</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga38ecee233f94e128bed9be3e530f27e5">pn_message_set_address</a>           (<a class="code" href="group__message.html#gad9259f
 a9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l00360"></a><span class="lineno">  360</span>&#160;</div><div class="line"><a name="l00375"></a><span class="lineno">  375</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c">pn_message_get_subject</a>           (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00376"></a><span class="lineno">  376</span>&#160;</div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa8594da8507dc031b1e0e89d51a2f281">pn_message_set_subject</a>           (<a class="code" href="group__message.html#gad9259
 fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *subject);</div><div class="line"><a name="l00390"></a><span class="lineno">  390</span>&#160;</div><div class="line"><a name="l00405"></a><span class="lineno">  405</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33">pn_message_get_reply_to</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00406"></a><span class="lineno">  406</span>&#160;</div><div class="line"><a name="l00419"></a><span class="lineno">  419</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313">pn_message_set_reply_to</a>          (<a class="code" href="group__message.html#gad925
 9fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *reply_to);</div><div class="line"><a name="l00420"></a><span class="lineno">  420</span>&#160;</div><div class="line"><a name="l00433"></a><span class="lineno">  433</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *    <a class="code" href="group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd">pn_message_correlation_id</a>        (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00434"></a><span class="lineno">  434</span>&#160;</div><div class="line"><a name="l00446"></a><span class="lineno">  446</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>      <a class="code" href="group__message.html#ga7c7a49b84141d130f885e3a6b357d65a">pn_message_get_correlation_id</a
 >    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00447"></a><span class="lineno">  447</span>&#160;</div><div class="line"><a name="l00459"></a><span class="lineno">  459</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a">pn_message_set_correlation_id</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#structpn__atom__t">pn_atom_t</a> <span class="keywordtype">id</span>);</div><div class="line"><a name="l00460"></a><span class="lineno">  460</span>&#160;</div><div class="line"><a name="l00475"></a><span class="lineno">  475</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga280a96bf80dd37a4062432f45e679ea1"
 >pn_message_get_content_type</a>      (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00476"></a><span class="lineno">  476</span>&#160;</div><div class="line"><a name="l00489"></a><span class="lineno">  489</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gaa0247560f0cd4590bc8ece20565eb611">pn_message_set_content_type</a>      (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *type);</div><div class="line"><a name="l00490"></a><span class="lineno">  490</span>&#160;</div><div class="line"><a name="l00505"></a><span class="lineno">  505</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#gacb97f21822b058b6297bc618f6d190b0">p
 n_message_get_content_encoding</a>  (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00506"></a><span class="lineno">  506</span>&#160;</div><div class="line"><a name="l00519"></a><span class="lineno">  519</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b">pn_message_set_content_encoding</a>  (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *encoding);</div><div class="line"><a name="l00520"></a><span class="lineno">  520</span>&#160;</div><div class="line"><a name="l00530"></a><span class="lineno">  530</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__message.html#ga8fdfd3dac
 a961bbfaa7affacee6047ce">pn_message_get_expiry_time</a>       (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00531"></a><span class="lineno">  531</span>&#160;</div><div class="line"><a name="l00541"></a><span class="lineno">  541</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga6c108bc39b13c5257671aee68ea981c7">pn_message_set_expiry_time</a>       (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> time);</div><div class="line"><a name="l00542"></a><span class="lineno">  542</span>&#160;</div><div class="line"><a name="l00552"></a><span class="lineno">  552</span>&#160;PN_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a c
 lass="code" href="group__message.html#ga4a18377a68cc26d68141e1b1afd82a52">pn_message_get_creation_time</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00553"></a><span class="lineno">  553</span>&#160;</div><div class="line"><a name="l00563"></a><span class="lineno">  563</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2">pn_message_set_creation_time</a>     (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> time);</div><div class="line"><a name="l00564"></a><span class="lineno">  564</span>&#160;</div><div class="line"><a name="l00579"></a><span class="lineno">  579</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordt
 ype">char</span> *   <a class="code" href="group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b">pn_message_get_group_id</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00580"></a><span class="lineno">  580</span>&#160;</div><div class="line"><a name="l00593"></a><span class="lineno">  593</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc">pn_message_set_group_id</a>          (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *group_id);</div><div class="line"><a name="l00594"></a><span class="lineno">  594</span>&#160;</div><div class="line"><a name="l00605"></a><span class="lineno">  605</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#ga92033ea
 a8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a>  <a class="code" href="group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4">pn_message_get_group_sequence</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;</div><div class="line"><a name="l00617"></a><span class="lineno">  617</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga2b9e17a8c639adba856130ad714ca31a">pn_message_set_group_sequence</a>    (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a> n);</div><div class="line"><a name="l00618"></a><span class="lineno">  618</span>&#160;</div><div class="line"><a name="l00633"></a><span class="lineno">  633</span>&#160;PN_EXTERN <span class
 ="keyword">const</span> <span class="keywordtype">char</span> *   <a class="code" href="group__message.html#ga7163a0174e7c71361172a1f6387f232a">pn_message_get_reply_to_group_id</a> (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00634"></a><span class="lineno">  634</span>&#160;</div><div class="line"><a name="l00647"></a><span class="lineno">  647</span>&#160;PN_EXTERN <span class="keywordtype">int</span>            <a class="code" href="group__message.html#ga304bbec66cac6f09f01cbf7014196fd9">pn_message_set_reply_to_group_id</a> (<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *reply_to_group_id);</div><div class="line"><a name="l00648"></a><span class="lineno">  648</span>&#160;</div><div class="line"><a name="l00664"></a><span class="lineno">  664</span>&#160;PN_EXTERN 
 <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga02347ad161f972e4b94567f329b53a8a">pn_message_instructions</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00665"></a><span class="lineno">  665</span>&#160;</div><div class="line"><a name="l00680"></a><span class="lineno">  680</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#gadadb16710eccb6d332d039acc9dc1042">pn_message_annotations</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00681"></a><span class="lineno">  681</span>&#160;</div><div class="line"><a name="l00696"></a><span class="lineno">  696</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf52
 8776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00697"></a><span class="lineno">  697</span>&#160;</div><div class="line"><a name="l00709"></a><span class="lineno">  709</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00710"></a><span class="lineno">  710</span>&#160;</div><div class="line"><a name="l00723"></a><span class="lineno">  723</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#gab0bae90838f4661b0c82c15f
 25e1e988">pn_message_decode</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00724"></a><span class="lineno">  724</span>&#160;</div><div class="line"><a name="l00738"></a><span class="lineno">  738</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> *size);</div><div class="line"><a name="l00739"></a><span class="lineno">  739</span>&#160;</div><div class="line"><a name="l00740"></a><span class="lineno">  740</span>&#160;<span class="keyword">struct </span><a class="code" href="gr
 oup__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>;</div><div class="line"><a name="l00741"></a><span class="lineno">  741</span>&#160;</div><div class="line"><a name="l00769"></a><span class="lineno">  769</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">pn_message_send</a>(<a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> *buf);</div><div class="line"><a name="l00770"></a><span class="lineno">  770</span>&#160;</div><div class="line"><a name="l00774"></a><span class="lineno">  774</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__message.html#ga013d429f94d653bc1e00f1f438a079a6">pn_message_data</a>(<a class="code" href="group__message.html#gad9
 259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data);</div><div class="line"><a name="l00775"></a><span class="lineno">  775</span>&#160;</div><div class="line"><a name="l00779"></a><span class="lineno">  779</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00780"></a><span class="lineno">  780</span>&#160;}</div><div class="line"><a name="l00781"></a><span class="lineno">  781</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00782"></a><span class="lineno">  782</span>&#160;</div><div class="line"><a name="l00783"></a><span class="lineno">  783</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* message.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__message_html_ga280a96bf80dd37a4062432f45e679ea1"><div class="ttname"><a href="group__message.htm
 l#ga280a96bf80dd37a4062432f45e679ea1">pn_message_get_content_type</a></div><div class="ttdeci">const char * pn_message_get_content_type(pn_message_t *msg)</div><div class="ttdoc">Get the content_type for a message. </div></div>
 <div class="ttc" id="group__message_html_gaa9a53e784afb72ea8a4d2033f99ce313"><div class="ttname"><a href="group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313">pn_message_set_reply_to</a></div><div class="ttdeci">int pn_message_set_reply_to(pn_message_t *msg, const char *reply_to)</div><div class="ttdoc">Set the reply_to for a message. </div></div>
-<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:147</div></div>
+<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:145</div></div>
 <div class="ttc" id="group__message_html_ga62c632d8bd001658cf6206eb5fac7e6c"><div class="ttname"><a href="group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c">pn_message_set_priority</a></div><div class="ttdeci">int pn_message_set_priority(pn_message_t *msg, uint8_t priority)</div><div class="ttdoc">Set the priority for a message. </div></div>
 <div class="ttc" id="group__message_html_ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4"><div class="ttname"><a href="group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4">pn_message_get_group_sequence</a></div><div class="ttdeci">pn_sequence_t pn_message_get_group_sequence(pn_message_t *msg)</div><div class="ttdoc">Get the group sequence for a message. </div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
@@ -104,8 +104,8 @@ $(document).ready(function(){initNavTree('message_8h_source.html','');});
 <div class="ttc" id="group__message_html_ga63f6065e770ddf435e38d8c0e01bc5ad"><div class="ttname"><a href="group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad">pn_message_set_durable</a></div><div class="ttdeci">int pn_message_set_durable(pn_message_t *msg, bool durable)</div><div class="ttdoc">Set the durable flag for a message. </div></div>
 <div class="ttc" id="group__message_html_gaa8594da8507dc031b1e0e89d51a2f281"><div class="ttname"><a href="group__message.html#gaa8594da8507dc031b1e0e89d51a2f281">pn_message_set_subject</a></div><div class="ttdeci">int pn_message_set_subject(pn_message_t *msg, const char *subject)</div><div class="ttdoc">Set the subject for a message. </div></div>
 <div class="ttc" id="group__message_html_ga296bd7b984c4b9cfabc297ab5badf7de"><div class="ttname"><a href="group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de">pn_message_id</a></div><div class="ttdeci">pn_data_t * pn_message_id(pn_message_t *msg)</div><div class="ttdoc">Get/set the id for a message. </div></div>
-<div class="ttc" id="group__message_html_ga43c7ee6ab70316145fb2bb5fcad210ad"><div class="ttname"><a href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a></div><div class="ttdeci">pn_data_t * pn_message_properties(pn_message_t *msg)</div><div class="ttdoc">Get/set the properties for a message. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__atom__t"><div class="ttname"><a href="group__api__types.html#structpn__atom__t">pn_atom_t</a></div><div class="ttdoc">A descriminated union that holds any scalar AMQP value. </div><div class="ttdef"><b>Definition:</b> codec.h:200</div></div>
+<div class="ttc" id="group__message_html_ga43c7ee6ab70316145fb2bb5fcad210ad"><div class="ttname"><a href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a></div><div class="ttdeci">pn_data_t * pn_message_properties(pn_message_t *msg)</div><div class="ttdoc">Get and set the properties for a message. </div></div>
+<div class="ttc" id="group__api__types_html_structpn__atom__t"><div class="ttname"><a href="group__api__types.html#structpn__atom__t">pn_atom_t</a></div><div class="ttdoc">A discriminated union that holds any scalar AMQP value. </div><div class="ttdef"><b>Definition:</b> codec.h:200</div></div>
 <div class="ttc" id="group__message_html_gac8a1e35c70d625b69e0d1769d9c898d2"><div class="ttname"><a href="group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2">pn_message_is_first_acquirer</a></div><div class="ttdeci">bool pn_message_is_first_acquirer(pn_message_t *msg)</div><div class="ttdoc">Get the first acquirer flag for a message. </div></div>
 <div class="ttc" id="group__message_html_ga5d9367609d74ca3511d4172806eeb55b"><div class="ttname"><a href="group__message.html#ga5d9367609d74ca3511d4172806eeb55b">pn_message_is_inferred</a></div><div class="ttdeci">bool pn_message_is_inferred(pn_message_t *msg)</div><div class="ttdoc">Get the inferred flag for a message. </div></div>
 <div class="ttc" id="group__message_html_ga7163a0174e7c71361172a1f6387f232a"><div class="ttname"><a href="group__message.html#ga7163a0174e7c71361172a1f6387f232a">pn_message_get_reply_to_group_id</a></div><div class="ttdeci">const char * pn_message_get_reply_to_group_id(pn_message_t *msg)</div><div class="ttdoc">Get the reply_to_group_id for a message. </div></div>
@@ -113,14 +113,16 @@ $(document).ready(function(){initNavTree('message_8h_source.html','');});
 <div class="ttc" id="group__message_html_gaaf98d84b9ddc1c6537dddd4c9c5b979e"><div class="ttname"><a href="group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e">pn_message</a></div><div class="ttdeci">pn_message_t * pn_message(void)</div><div class="ttdoc">Construct a new pn_message_t. </div></div>
 <div class="ttc" id="group__message_html_gaa0247560f0cd4590bc8ece20565eb611"><div class="ttname"><a href="group__message.html#gaa0247560f0cd4590bc8ece20565eb611">pn_message_set_content_type</a></div><div class="ttdeci">int pn_message_set_content_type(pn_message_t *msg, const char *type)</div><div class="ttdoc">Set the content_type for a message. </div></div>
 <div class="ttc" id="group__message_html_ga4a18377a68cc26d68141e1b1afd82a52"><div class="ttname"><a href="group__message.html#ga4a18377a68cc26d68141e1b1afd82a52">pn_message_get_creation_time</a></div><div class="ttdeci">pn_timestamp_t pn_message_get_creation_time(pn_message_t *msg)</div><div class="ttdoc">Get the creation time for a message. </div></div>
+<div class="ttc" id="group__api__types_html_structpn__rwbytes__t"><div class="ttname"><a href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a></div><div class="ttdoc">A non-const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:231</div></div>
 <div class="ttc" id="codec_8h_html"><div class="ttname"><a href="codec_8h.html">codec.h</a></div><div class="ttdoc">AMQP data encoding and decoding. </div></div>
+<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:311</div></div>
 <div class="ttc" id="group__message_html_gaf35cc7fb503f99b434a970ff669e5c4c"><div class="ttname"><a href="group__message.html#gaf35cc7fb503f99b434a970ff669e5c4c">pn_message_get_subject</a></div><div class="ttdeci">const char * pn_message_get_subject(pn_message_t *msg)</div><div class="ttdoc">Get the subject for a message. </div></div>
 <div class="ttc" id="group__message_html_gacb97f21822b058b6297bc618f6d190b0"><div class="ttname"><a href="group__message.html#gacb97f21822b058b6297bc618f6d190b0">pn_message_get_content_encoding</a></div><div class="ttdeci">const char * pn_message_get_content_encoding(pn_message_t *msg)</div><div class="ttdoc">Get the content_encoding for a message. </div></div>
 <div class="ttc" id="group__message_html_ga8fdfd3daca961bbfaa7affacee6047ce"><div class="ttname"><a href="group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce">pn_message_get_expiry_time</a></div><div class="ttdeci">pn_timestamp_t pn_message_get_expiry_time(pn_message_t *msg)</div><div class="ttdoc">Get the expiry time for a message. </div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
 <div class="ttc" id="group__message_html_gac10c5d8f12e4817fec126fdb608baf53"><div class="ttname"><a href="group__message.html#gac10c5d8f12e4817fec126fdb608baf53">pn_message_errno</a></div><div class="ttdeci">int pn_message_errno(pn_message_t *msg)</div><div class="ttdoc">Access the error code of a message. </div></div>
 <div class="ttc" id="group__message_html_gaceb08618e468fdb4a95e103cce6e7cbd"><div class="ttname"><a href="group__message.html#gaceb08618e468fdb4a95e103cce6e7cbd">pn_message_correlation_id</a></div><div class="ttdeci">pn_data_t * pn_message_correlation_id(pn_message_t *msg)</div><div class="ttdoc">Get/set the correlation id for a message. </div></div>
-<div class="ttc" id="group__api__types_html_ga92033eaa8a158e7e4bb5d1f0e94ca606"><div class="ttname"><a href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a></div><div class="ttdeci">int32_t pn_sequence_t</div><div class="ttdoc">A sequence number. </div><div class="ttdef"><b>Definition:</b> types.h:140</div></div>
+<div class="ttc" id="group__api__types_html_ga92033eaa8a158e7e4bb5d1f0e94ca606"><div class="ttname"><a href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a></div><div class="ttdeci">int32_t pn_sequence_t</div><div class="ttdoc">A sequence number. </div><div class="ttdef"><b>Definition:</b> types.h:138</div></div>
 <div class="ttc" id="group__message_html_ga69aadbc3a80f1fa16962774e711392f8"><div class="ttname"><a href="group__message.html#ga69aadbc3a80f1fa16962774e711392f8">pn_message_free</a></div><div class="ttdeci">void pn_message_free(pn_message_t *msg)</div><div class="ttdoc">Free a previously constructed pn_message_t. </div></div>
 <div class="ttc" id="group__message_html_gad514ef95e642698876bedf6ec772eb72"><div class="ttname"><a href="group__message.html#gad514ef95e642698876bedf6ec772eb72">pn_message_get_delivery_count</a></div><div class="ttdeci">uint32_t pn_message_get_delivery_count(pn_message_t *msg)</div><div class="ttdoc">Get the delivery count for a message. </div></div>
 <div class="ttc" id="group__message_html_ga64240467da74892010a7282116b0b234"><div class="ttname"><a href="group__message.html#ga64240467da74892010a7282116b0b234">pn_message_set_first_acquirer</a></div><div class="ttdeci">int pn_message_set_first_acquirer(pn_message_t *msg, bool first)</div><div class="ttdoc">Set the first acquirer flag for a message. </div></div>
@@ -128,7 +130,7 @@ $(document).ready(function(){initNavTree('message_8h_source.html','');});
 <div class="ttc" id="group__message_html_ga304bbec66cac6f09f01cbf7014196fd9"><div class="ttname"><a href="group__message.html#ga304bbec66cac6f09f01cbf7014196fd9">pn_message_set_reply_to_group_id</a></div><div class="ttdeci">int pn_message_set_reply_to_group_id(pn_message_t *msg, const char *reply_to_group_id)</div><div class="ttdoc">Set the reply_to_group_id for a message. </div></div>
 <div class="ttc" id="group__message_html_ga918c90a049d6b39041b0a2044f9048c6"><div class="ttname"><a href="group__message.html#ga918c90a049d6b39041b0a2044f9048c6">pn_message_clear</a></div><div class="ttdeci">void pn_message_clear(pn_message_t *msg)</div><div class="ttdoc">Clears the content of a pn_message_t. </div></div>
 <div class="ttc" id="group__message_html_gab7f1c0d93b93dee6c3eef730e35ef5e2"><div class="ttname"><a href="group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2">pn_message_set_creation_time</a></div><div class="ttdeci">int pn_message_set_creation_time(pn_message_t *msg, pn_timestamp_t time)</div><div class="ttdoc">Set the creation time for a message. </div></div>
-<div class="ttc" id="group__message_html_ga2173bbce3c1f4b04074e42d2fe7da473"><div class="ttname"><a href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a></div><div class="ttdeci">int pn_message_encode(pn_message_t *msg, char *bytes, size_t *size)</div><div class="ttdoc">Encode/save message content as AMQP formatted binary data. </div></div>
+<div class="ttc" id="group__message_html_ga2173bbce3c1f4b04074e42d2fe7da473"><div class="ttname"><a href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a></div><div class="ttdeci">int pn_message_encode(pn_message_t *msg, char *bytes, size_t *size)</div><div class="ttdoc">Encode a message as AMQP formatted binary data. </div></div>
 <div class="ttc" id="group__message_html_ga4ebc7c7e7f524f5bf36214ff0ccaa00b"><div class="ttname"><a href="group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b">pn_message_get_group_id</a></div><div class="ttdeci">const char * pn_message_get_group_id(pn_message_t *msg)</div><div class="ttdoc">Get the group_id for a message. </div></div>
 <div class="ttc" id="group__message_html_ga957f54f40b8a297cdf9ceee8a71b3c1c"><div class="ttname"><a href="group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c">pn_message_get_user_id</a></div><div class="ttdeci">pn_bytes_t pn_message_get_user_id(pn_message_t *msg)</div><div class="ttdoc">Get the user id for a message. </div></div>
 <div class="ttc" id="group__message_html_gad7d3aa060b7666dce6a6d955945bedce"><div class="ttname"><a href="group__message.html#gad7d3aa060b7666dce6a6d955945bedce">pn_message_get_id</a></div><div class="ttdeci">pn_atom_t pn_message_get_id(pn_message_t *msg)</div><div class="ttdoc">Get the id for a message. </div></div>
@@ -148,12 +150,13 @@ $(document).ready(function(){initNavTree('message_8h_source.html','');});
 <div class="ttc" id="group__message_html_ga0ec7ed8750b4d418c60aa77e4b1812bc"><div class="ttname"><a href="group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc">pn_message_set_group_id</a></div><div class="ttdeci">int pn_message_set_group_id(pn_message_t *msg, const char *group_id)</div><div class="ttdoc">Set the group_id for a message. </div></div>
 <div class="ttc" id="group__message_html_gaa4f5b4884d5422123a4e6f48bf00701c"><div class="ttname"><a href="group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c">pn_message_get_address</a></div><div class="ttdeci">const char * pn_message_get_address(pn_message_t *msg)</div><div class="ttdoc">Get the address for a message. </div></div>
 <div class="ttc" id="group__message_html_ga63bdd43b7cee8741665db999fac97a62"><div class="ttname"><a href="group__message.html#ga63bdd43b7cee8741665db999fac97a62">pn_message_set_inferred</a></div><div class="ttdeci">int pn_message_set_inferred(pn_message_t *msg, bool inferred)</div><div class="ttdoc">Set the inferred flag for a message. </div></div>
+<div class="ttc" id="group__message_html_ga86cd32577f0e78bab29bd0e49869f0b5"><div class="ttname"><a href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">pn_message_send</a></div><div class="ttdeci">ssize_t pn_message_send(pn_message_t *msg, pn_link_t *sender, pn_rwbytes_t *buf)</div><div class="ttdoc">Encode and send a message on a sender link. </div></div>
 <div class="ttc" id="group__message_html_ga6c108bc39b13c5257671aee68ea981c7"><div class="ttname"><a href="group__message.html#ga6c108bc39b13c5257671aee68ea981c7">pn_message_set_expiry_time</a></div><div class="ttdeci">int pn_message_set_expiry_time(pn_message_t *msg, pn_timestamp_t time)</div><div class="ttdoc">Set the expiry time for a message. </div></div>
 <div class="ttc" id="group__message_html_gadadb16710eccb6d332d039acc9dc1042"><div class="ttname"><a href="group__message.html#gadadb16710eccb6d332d039acc9dc1042">pn_message_annotations</a></div><div class="ttdeci">pn_data_t * pn_message_annotations(pn_message_t *msg)</div><div class="ttdoc">Get/set the annotations for a message. </div></div>
 <div class="ttc" id="group__message_html_ga38ecee233f94e128bed9be3e530f27e5"><div class="ttname"><a href="group__message.html#ga38ecee233f94e128bed9be3e530f27e5">pn_message_set_address</a></div><div class="ttdeci">int pn_message_set_address(pn_message_t *msg, const char *address)</div><div class="ttdoc">Set the address for a message. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:214</div></div>
-<div class="ttc" id="group__message_html_ga145c06edbcccfbe97136bfb5cb2b22b1"><div class="ttname"><a href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a></div><div class="ttdeci">pn_data_t * pn_message_body(pn_message_t *msg)</div><div class="ttdoc">Get/set the body of a message. </div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:168</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
+<div class="ttc" id="group__message_html_ga145c06edbcccfbe97136bfb5cb2b22b1"><div class="ttname"><a href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a></div><div class="ttdeci">pn_data_t * pn_message_body(pn_message_t *msg)</div><div class="ttdoc">Get and set the body of a message. </div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 <div class="ttc" id="group__message_html_gad169c319e27eacf91864da26a23b6d74"><div class="ttname"><a href="group__message.html#gad169c319e27eacf91864da26a23b6d74">pn_message_set_id</a></div><div class="ttdeci">int pn_message_set_id(pn_message_t *msg, pn_atom_t id)</div><div class="ttdoc">Set the id for a message. </div></div>
 <div class="ttc" id="group__message_html_ga5b9e011902e7bd3a9f94ecf52b723c33"><div class="ttname"><a href="group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33">pn_message_get_reply_to</a></div><div class="ttdeci">const char * pn_message_get_reply_to(pn_message_t *msg)</div><div class="ttdoc">Get the reply_to for a message. </div></div>
 </div><!-- fragment --></div><!-- contents -->


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


[22/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/types_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/types_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/types_8h_source.html
index f2e03d3..dc26244 100755
--- a/content/releases/qpid-proton-master/proton/c/api/types_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/types_8h_source.html
@@ -93,30 +93,30 @@ $(document).ready(function(){initNavTree('types_8h_source.html','');});
 <div class="title">types.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="types_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TYPES_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TYPES_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreement
 s.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comm
 ent"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div>
 <div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160
 ;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00140"></a><span class="lineno"><a class="line" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">  140</a></span>&#160;<span class="keyword">typedef</span> int32_t  <a class="code" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a>;</div><div cl
 ass="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno"><a class="line" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">  147</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;</div><div class="line"><a name="l00154"></a><span class="lineno"><a class="line" href="group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64">  154</a></span>&#160;<span class="preprocessor">#define PN_MILLIS_MAX (~0U)</span></div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00161"></a><span class="lineno"><a class="line" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">  161</a></span>&#160;<span class="keyword">typedef</span> uint32_t <
 a class="code" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a>;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno"><a class="line" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">  168</a></span>&#160;<span class="keyword">typedef</span> int64_t <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a>;</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;</div><div class="line"><a name="l00175"></a><span class="lineno"><a class="line" href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">  175</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a>;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;</div><div class="li
 ne"><a name="l00182"></a><span class="lineno"><a class="line" href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">  182</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a>;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno"><a class="line" href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">  189</a></span>&#160;<span class="keyword">typedef</span> uint64_t <a class="code" href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a>;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno"><a class="line" href="group__amqp__types.html">  196</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>{</div>
 <div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;  <span class="keywordtype">char</span> bytes[16];</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;} <a class="code" href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a>;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno"><a class="line" href="group__amqp__types.html">  205</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>{</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;  <span class="keywordtype">char</span> bytes[16];</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;} <a class="code" href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a>;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;</div><div class
 ="line"><a name="l00214"></a><span class="lineno"><a class="line" href="group__api__types.html">  214</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> {</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;  <span class="keywordtype">size_t</span> size;</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;  <span class="keyword">const</span> <span class="keywordtype">char</span> *start;</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;} <a class="code" href="group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748">pn_bytes_t</a>;</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;</div><div class="line"><a name="l00224"></a><span class="lineno">  224</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_
 bytes_t</a> <a class="code" href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(<span class="keywordtype">size_t</span> size, <span class="keyword">const</span> <span class="keywordtype">char</span> *start);</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;<span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> pn_bytes_null = { 0, NULL };</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;</div><div class="line"><a name="l00233"></a><span class="lineno"><a class="line" href="group__api__types.html">  233</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> {</div><div class="line"><a name="l00234">
 </a><span class="lineno">  234</span>&#160;  <span class="keywordtype">size_t</span> size;</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;  <span class="keywordtype">char</span> *start;</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;} <a class="code" href="group__api__types.html#ga1f6bde2a01737366adcbfee546035b78">pn_rwbytes_t</a>;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> <a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(<span class="keywordtype">size_t</span> size, <span class="keywordtype">char</span> *start);</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;</div><div class="line"><a name="l00245"></a><span class="
 lineno">  245</span>&#160;<span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> pn_rwbytes_null = { 0, NULL };</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line"><a name="l00269"></a><span class="lineno"><a class="line" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">  269</a></span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a>;</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;</div><div class="line"><a name="l00283"></a><span class="lineno"><a class="line" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">  283</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__connection.h
 tml#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;</div><div class="line"><a name="l00294"></a><span class="lineno"><a class="line" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">  294</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a>;</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;</div><div class="line"><a name="l00313"></a><span class="lineno"><a class="line" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">  313</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a 
 class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>;</div><div class="line"><a name="l00314"></a><span class="lineno">  314</span>&#160;</div><div class="line"><a name="l00403"></a><span class="lineno"><a class="line" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">  403</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a>;</div><div class="line"><a name="l00404"></a><span class="lineno">  404</span>&#160;</div><div class="line"><a name="l00415"></a><span class="lineno"><a class="line" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">  415</a></span>&#160;<span class="keyword">typedef</span> <span class="keywor
 d">struct </span><a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a>;</div><div class="line"><a name="l00416"></a><span class="lineno">  416</span>&#160;</div><div class="line"><a name="l00422"></a><span class="lineno"><a class="line" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">  422</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>;</div><div class="line"><a name="l00423"></a><span class="lineno">  423</span>&#160;</div><div class="line"><a name="l00433"></a><span class="lineno"><a class="line" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">  433</a></span>&#160;<span class="keyword
 ">typedef</span> <span class="keyword">struct </span><a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a>;</div><div class="line"><a name="l00434"></a><span class="lineno">  434</span>&#160;</div><div class="line"><a name="l00440"></a><span class="lineno"><a class="line" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">  440</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a>;</div><div class="line"><a name="l00441"></a><span class="lineno">  441</span>&#160;</div><div class="line"><a name="l00449"></a><span class="lineno">  449</span>&#160;<span class="keyword">typedef</span> <span class="keyword">s
 truct </span>pn_handler_t pn_handler_t;</div><div class="line"><a name="l00454"></a><span class="lineno">  454</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00455"></a><span class="lineno">  455</span>&#160;}</div><div class="line"><a name="l00456"></a><span class="lineno">  456</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00457"></a><span class="lineno">  457</span>&#160;</div><div class="line"><a name="l00458"></a><span class="lineno">  458</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* types.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="t
 tdef"><b>Definition:</b> types.h:422</div></div>
-<div class="ttc" id="group__amqp__types_html_ga54d49ca7ff04ad10a57139c2d61f1d44"><div class="ttname"><a href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a></div><div class="ttdeci">uint32_t pn_decimal32_t</div><div class="ttdoc">A 32-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:182</div></div>
-<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:147</div></div>
+<a href="types_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TYPES_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TYPES_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreement
 s.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comm
 ent"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div>
 <div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160
 ;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00138"></a><span class="lineno"><a class="line" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">  138</a></span>&#160;<span class="keyword">typedef</span> int32_t  <a class="code" href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a>;</div><div cl
 ass="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno"><a class="line" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">  145</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno"><a class="line" href="group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64">  152</a></span>&#160;<span class="preprocessor">#define PN_MILLIS_MAX (~0U)</span></div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno"><a class="line" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">  159</a></span>&#160;<span class="keyword">typedef</span> uint32_t <
 a class="code" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a>;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00166"></a><span class="lineno"><a class="line" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">  166</a></span>&#160;<span class="keyword">typedef</span> int64_t <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a>;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno"><a class="line" href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">  173</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a>;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;</div><div class="li
 ne"><a name="l00180"></a><span class="lineno"><a class="line" href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">  180</a></span>&#160;<span class="keyword">typedef</span> uint32_t <a class="code" href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a>;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;</div><div class="line"><a name="l00187"></a><span class="lineno"><a class="line" href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">  187</a></span>&#160;<span class="keyword">typedef</span> uint64_t <a class="code" href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a>;</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;</div><div class="line"><a name="l00194"></a><span class="lineno"><a class="line" href="group__amqp__types.html">  194</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>{</div>
 <div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;  <span class="keywordtype">char</span> bytes[16];</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;} <a class="code" href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a>;</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;</div><div class="line"><a name="l00203"></a><span class="lineno"><a class="line" href="group__amqp__types.html">  203</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>{</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;  <span class="keywordtype">char</span> bytes[16];</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;} <a class="code" href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a>;</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class
 ="line"><a name="l00212"></a><span class="lineno"><a class="line" href="group__api__types.html">  212</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> {</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;  <span class="keywordtype">size_t</span> size;</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;  <span class="keyword">const</span> <span class="keywordtype">char</span> *start;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;} <a class="code" href="group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748">pn_bytes_t</a>;</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_
 bytes_t</a> <a class="code" href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a>(<span class="keywordtype">size_t</span> size, <span class="keyword">const</span> <span class="keywordtype">char</span> *start);</div><div class="line"><a name="l00223"></a><span class="lineno">  223</span>&#160;</div><div class="line"><a name="l00224"></a><span class="lineno">  224</span>&#160;<span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> pn_bytes_null = { 0, NULL };</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;</div><div class="line"><a name="l00231"></a><span class="lineno"><a class="line" href="group__api__types.html">  231</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> {</div><div class="line"><a name="l00232">
 </a><span class="lineno">  232</span>&#160;  <span class="keywordtype">size_t</span> size;</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;  <span class="keywordtype">char</span> *start;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;} <a class="code" href="group__api__types.html#ga1f6bde2a01737366adcbfee546035b78">pn_rwbytes_t</a>;</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00241"></a><span class="lineno">  241</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> <a class="code" href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a>(<span class="keywordtype">size_t</span> size, <span class="keywordtype">char</span> *start);</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;</div><div class="line"><a name="l00243"></a><span class="
 lineno">  243</span>&#160;<span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> pn_rwbytes_null = { 0, NULL };</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno"><a class="line" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">  267</a></span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a>;</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00281"></a><span class="lineno"><a class="line" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">  281</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__connecti
 on.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>;</div><div class="line"><a name="l00282"></a><span class="lineno">  282</span>&#160;</div><div class="line"><a name="l00292"></a><span class="lineno"><a class="line" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">  292</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a>;</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;</div><div class="line"><a name="l00311"></a><span class="lineno"><a class="line" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">  311</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span
 ><a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a>;</div><div class="line"><a name="l00312"></a><span class="lineno">  312</span>&#160;</div><div class="line"><a name="l00401"></a><span class="lineno"><a class="line" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">  401</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a>;</div><div class="line"><a name="l00402"></a><span class="lineno">  402</span>&#160;</div><div class="line"><a name="l00413"></a><span class="lineno"><a class="line" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">  413</a></span>&#160;<span class="keyword">typedef</span> <span class="ke
 yword">struct </span><a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a>;</div><div class="line"><a name="l00414"></a><span class="lineno">  414</span>&#160;</div><div class="line"><a name="l00420"></a><span class="lineno"><a class="line" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">  420</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>;</div><div class="line"><a name="l00421"></a><span class="lineno">  421</span>&#160;</div><div class="line"><a name="l00431"></a><span class="lineno"><a class="line" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">  431</a></span>&#160;<span class="key
 word">typedef</span> <span class="keyword">struct </span><a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a>;</div><div class="line"><a name="l00432"></a><span class="lineno">  432</span>&#160;</div><div class="line"><a name="l00438"></a><span class="lineno"><a class="line" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">  438</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a>;</div><div class="line"><a name="l00439"></a><span class="lineno">  439</span>&#160;</div><div class="line"><a name="l00447"></a><span class="lineno">  447</span>&#160;<span class="keyword">typedef</span> <span class="keywor
 d">struct </span>pn_handler_t pn_handler_t;</div><div class="line"><a name="l00452"></a><span class="lineno">  452</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00453"></a><span class="lineno">  453</span>&#160;}</div><div class="line"><a name="l00454"></a><span class="lineno">  454</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00455"></a><span class="lineno">  455</span>&#160;</div><div class="line"><a name="l00456"></a><span class="lineno">  456</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* types.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div clas
 s="ttdef"><b>Definition:</b> types.h:420</div></div>
+<div class="ttc" id="group__amqp__types_html_ga54d49ca7ff04ad10a57139c2d61f1d44"><div class="ttname"><a href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a></div><div class="ttdeci">uint32_t pn_decimal32_t</div><div class="ttdoc">A 32-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:180</div></div>
+<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:145</div></div>
 <div class="ttc" id="group__api__types_html_ga9fb5bee0255a52b1b8b8fa1b8620cbca"><div class="ttname"><a href="group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca">pn_rwbytes</a></div><div class="ttdeci">pn_rwbytes_t pn_rwbytes(size_t size, char *start)</div><div class="ttdoc">Create a pn_rwbytes_t. </div></div>
-<div class="ttc" id="group__amqp__types_html_structpn__uuid__t"><div class="ttname"><a href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a></div><div class="ttdoc">A 16-byte universally unique identifier. </div><div class="ttdef"><b>Definition:</b> types.h:205</div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
-<div class="ttc" id="group__api__types_html_structpn__rwbytes__t"><div class="ttname"><a href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a></div><div class="ttdoc">A non-const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:233</div></div>
-<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:313</div></div>
+<div class="ttc" id="group__amqp__types_html_structpn__uuid__t"><div class="ttname"><a href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a></div><div class="ttdoc">A 16-byte universally unique identifier. </div><div class="ttdef"><b>Definition:</b> types.h:203</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
+<div class="ttc" id="group__api__types_html_structpn__rwbytes__t"><div class="ttname"><a href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a></div><div class="ttdoc">A non-const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:231</div></div>
+<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:311</div></div>
 <div class="ttc" id="group__api__types_html_ga1f6bde2a01737366adcbfee546035b78"><div class="ttname"><a href="group__api__types.html#ga1f6bde2a01737366adcbfee546035b78">pn_rwbytes_t</a></div><div class="ttdeci">struct pn_rwbytes_t pn_rwbytes_t</div><div class="ttdoc">A non-const byte buffer. </div></div>
-<div class="ttc" id="group__api__types_html_ga92033eaa8a158e7e4bb5d1f0e94ca606"><div class="ttname"><a href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a></div><div class="ttdeci">int32_t pn_sequence_t</div><div class="ttdoc">A sequence number. </div><div class="ttdef"><b>Definition:</b> types.h:140</div></div>
+<div class="ttc" id="group__api__types_html_ga92033eaa8a158e7e4bb5d1f0e94ca606"><div class="ttname"><a href="group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606">pn_sequence_t</a></div><div class="ttdeci">int32_t pn_sequence_t</div><div class="ttdoc">A sequence number. </div><div class="ttdef"><b>Definition:</b> types.h:138</div></div>
 <div class="ttc" id="group__api__types_html_ga26974f59df66946e2fe1f7e0ef5e9748"><div class="ttname"><a href="group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748">pn_bytes_t</a></div><div class="ttdeci">struct pn_bytes_t pn_bytes_t</div><div class="ttdoc">A const byte buffer. </div></div>
-<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:415</div></div>
-<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:294</div></div>
+<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
+<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:292</div></div>
 <div class="ttc" id="group__api__types_html_gab4f7e8d204246a3702c6e31a404b0edb"><div class="ttname"><a href="group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb">pn_bytes</a></div><div class="ttdeci">pn_bytes_t pn_bytes(size_t size, const char *start)</div><div class="ttdoc">Create a pn_bytes_t. </div></div>
-<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:440</div></div>
-<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:403</div></div>
-<div class="ttc" id="group__amqp__types_html_structpn__decimal128__t"><div class="ttname"><a href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a></div><div class="ttdoc">A 128-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:196</div></div>
-<div class="ttc" id="group__amqp__types_html_ga7d8110bc953738d83ad8b9c543ef517f"><div class="ttname"><a href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a></div><div class="ttdeci">uint64_t pn_decimal64_t</div><div class="ttdoc">A 64-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:189</div></div>
-<div class="ttc" id="group__api__types_html_gafdede9be0526a8d0b9ab5d3149069af1"><div class="ttname"><a href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a></div><div class="ttdeci">uint32_t pn_seconds_t</div><div class="ttdoc">A span of time in seconds. </div><div class="ttdef"><b>Definition:</b> types.h:161</div></div>
-<div class="ttc" id="group__amqp__types_html_gaa1713f25d484600197d2a25ace856672"><div class="ttname"><a href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a></div><div class="ttdeci">uint32_t pn_char_t</div><div class="ttdoc">A 32-bit Unicode code point. </div><div class="ttdef"><b>Definition:</b> types.h:175</div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
-<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:269</div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:214</div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:168</div></div>
+<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:438</div></div>
+<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:401</div></div>
+<div class="ttc" id="group__amqp__types_html_structpn__decimal128__t"><div class="ttname"><a href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a></div><div class="ttdoc">A 128-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:194</div></div>
+<div class="ttc" id="group__amqp__types_html_ga7d8110bc953738d83ad8b9c543ef517f"><div class="ttname"><a href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a></div><div class="ttdeci">uint64_t pn_decimal64_t</div><div class="ttdoc">A 64-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:187</div></div>
+<div class="ttc" id="group__api__types_html_gafdede9be0526a8d0b9ab5d3149069af1"><div class="ttname"><a href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a></div><div class="ttdeci">uint32_t pn_seconds_t</div><div class="ttdoc">A span of time in seconds. </div><div class="ttdef"><b>Definition:</b> types.h:159</div></div>
+<div class="ttc" id="group__amqp__types_html_gaa1713f25d484600197d2a25ace856672"><div class="ttname"><a href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a></div><div class="ttdeci">uint32_t pn_char_t</div><div class="ttdoc">A 32-bit Unicode code point. </div><div class="ttdef"><b>Definition:</b> types.h:173</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
+<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:267</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/url_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/url_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/url_8h_source.html
index 94238ff..b120b72 100755
--- a/content/releases/qpid-proton-master/proton/c/api/url_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/url_8h_source.html
@@ -93,9 +93,9 @@ $(document).ready(function(){initNavTree('url_8h_source.html','');});
 <div class="title">url.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="url_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_URL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_URL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span c
 lass="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> 
 *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * specific language 
 governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00027"></a><span class="lineno">   27<
 /span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno"><a class="line" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">   42</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a>;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;PNX_EXTERN <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *<a class="code" href="group__url.html#ga8b19840fe7ff1166c6583a7445eed325">pn_url</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00048"></a><span class="lin
 eno">   48</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;PNX_EXTERN <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *<a class="code" href="group__url.html#gaaa9f2f29b90525fbf73739cae8b84776">pn_url_parse</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *url);</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1">pn_url_free</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a c
 lass="code" href="group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b">pn_url_clear</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d">pn_url_str</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_scheme(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="
 line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_username(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_password(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_host(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_u
 rl_get_port(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_path(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_scheme(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *scheme);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_username(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span c
 lass="keywordtype">char</span> *username);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_password(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_host(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *host);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_port(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">
 char</span> *port);</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_path(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *path);</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;}</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* url.h */</span><span class="preprocessor"></span></div><div class="ttc" id="g
 roup__url_html_ga2f7548b8247ebddc8be3f0f5ebce151b"><div class="ttname"><a href="group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b">pn_url_clear</a></div><div class="ttdeci">void pn_url_clear(pn_url_t *url)</div><div class="ttdoc">Clear the contents of the URL. </div></div>
+<a href="url_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_URL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_URL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span c
 lass="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> 
 *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * specific language 
 governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00027"></a><span class="lineno">   27<
 /span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno"><a class="line" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">   41</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a>;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;PNX_EXTERN <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *<a class="code" href="group__url.html#ga8b19840fe7ff1166c6583a7445eed325">pn_url</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00047"></a><span class="lin
 eno">   47</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;PNX_EXTERN <a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *<a class="code" href="group__url.html#gaaa9f2f29b90525fbf73739cae8b84776">pn_url_parse</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *url);</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1">pn_url_free</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a c
 lass="code" href="group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b">pn_url_clear</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d">pn_url_str</a>(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_scheme(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="
 line"><a name="l00093"></a><span class="lineno">   93</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_username(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_password(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_host(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_u
 rl_get_port(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pn_url_get_path(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_scheme(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *scheme);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_username(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span c
 lass="keywordtype">char</span> *username);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_password(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_host(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *host);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_port(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">
 char</span> *port);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_url_set_path(<a class="code" href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a> *url, <span class="keyword">const</span> <span class="keywordtype">char</span> *path);</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;}</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* url.h */</span><span class="preprocessor"></span></div><div class="ttc" id="g
 roup__url_html_ga2f7548b8247ebddc8be3f0f5ebce151b"><div class="ttname"><a href="group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b">pn_url_clear</a></div><div class="ttdeci">void pn_url_clear(pn_url_t *url)</div><div class="ttdoc">Clear the contents of the URL. </div></div>
 <div class="ttc" id="group__url_html_gab65d8b2c49f5e3f720cea8a3c1a1e6d1"><div class="ttname"><a href="group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1">pn_url_free</a></div><div class="ttdeci">void pn_url_free(pn_url_t *url)</div><div class="ttdoc">Free a URL. </div></div>
-<div class="ttc" id="group__url_html_gafbe4340c29b1abd7394767456ad3b8ea"><div class="ttname"><a href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a></div><div class="ttdeci">struct pn_url_t pn_url_t</div><div class="ttdoc">A parsed URL. </div><div class="ttdef"><b>Definition:</b> url.h:42</div></div>
+<div class="ttc" id="group__url_html_gafbe4340c29b1abd7394767456ad3b8ea"><div class="ttname"><a href="group__url.html#gafbe4340c29b1abd7394767456ad3b8ea">pn_url_t</a></div><div class="ttdeci">struct pn_url_t pn_url_t</div><div class="ttdoc">A parsed URL. </div><div class="ttdef"><b>Definition:</b> url.h:41</div></div>
 <div class="ttc" id="group__url_html_gaaa9f2f29b90525fbf73739cae8b84776"><div class="ttname"><a href="group__url.html#gaaa9f2f29b90525fbf73739cae8b84776">pn_url_parse</a></div><div class="ttdeci">pn_url_t * pn_url_parse(const char *url)</div><div class="ttdoc">Parse a string URL as a pn_url_t. </div></div>
 <div class="ttc" id="group__url_html_ga8b19840fe7ff1166c6583a7445eed325"><div class="ttname"><a href="group__url.html#ga8b19840fe7ff1166c6583a7445eed325">pn_url</a></div><div class="ttdeci">pn_url_t * pn_url(void)</div><div class="ttdoc">Create an empty URL. </div></div>
 <div class="ttc" id="group__url_html_ga7e10d384560ab3e2bc9bbe219883e21d"><div class="ttname"><a href="group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d">pn_url_str</a></div><div class="ttdeci">const char * pn_url_str(pn_url_t *url)</div><div class="ttdoc">Return the string form of a URL. </div></div>


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


[07/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/endpoint_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/endpoint_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/endpoint_8hpp_source.html
index 2203f43..765389e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/endpoint_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/endpoint_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('endpoint_8hpp_source.html','');});
 <div class="title">endpoint.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="endpoint_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ENDPOINT_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ENDPOINT_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor lice
 nse agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the
 </span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="error__condition_8hpp.html">./err
 or_condition.hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno"><a class="line" href="classproton_1_1endpoint.html">   36</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00037
 "></a><span class="lineno">   37</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> ~<a class="code" href="classproton_1_1endpoint.html">endpoint</a>();</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;    <span class="comment">// XXX Add the container accessor here.</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;    </div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</s
 pan> = 0;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;    </div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> active() <span class="keyword">const</span> = 0;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;    </div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> closed() <span class="keyword">const</span> = 0;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    <span class="keyword">virtual</span> <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const = 0;</div><div class="line"><a name="l00054"></a><sp
 an class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    <span class="comment">// XXX Add virtual open() and open(endpoint_options)</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;    </div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> close() = 0;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;) = 0;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno"> 
   67</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_DEFAULTED_FUNCTIONS</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    <span class="comment">// Make everything explicit for C++11 compilers</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>() = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp; operator=(<span class="keyword">const</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint<
 /a>&amp; operator=(<a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>(<a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;};</div><div class="line"><a name="l00079"></a><span class="lineno">   79</sp
 an>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="keyword">namespace </span>internal {</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T, <span class="keyword">class</span> D&gt; <span class="keyword">class </span>iter_base {</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    <span class="keyword">typedef</span> T value_type;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    T operator*()<span class="keyword"> const </span>{ <span class="keywordflow">return</spa
 n> obj_; }</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    T* operator-&gt;()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> <span class="keyword">const_cast&lt;</span>T*<span class="keyword">&gt;</span>(&amp;obj_); }</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    D operator++(<span class="keywordtype">int</span>) { D x(*<span class="keyword">this</span>); ++(*this); <span class="keywordflow">return</span> x; }</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    <span class="keywordtype">bool</span> operator==(<span class="keyword">const</span> iter_base&lt;T, D&gt;&amp; x)<span class="keyword"> const </span>{ <span class="keywordflow">return</span> obj_ == x.obj_; }</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    <span class="keywordtype">bool</span> operator!=(<span class="keyword">const</span> iter_b
 ase&lt;T, D&gt;&amp; x)<span class="keyword"> const </span>{ <span class="keywordflow">return</span> obj_ != x.obj_; }</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    </div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;  <span class="keyword">protected</span>:</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    <span class="keyword">explicit</span> iter_base(T p = 0) : obj_(p) {}</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    T obj_;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;};</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">class</span> I&gt; <span class="keyword">class </span>iter_range {</div><div class="line"><a name
 ="l00098"></a><span class="lineno">   98</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;    <span class="keyword">typedef</span> I iterator;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    <span class="keyword">explicit</span> iter_range(I begin = I(), I end = I()) : begin_(begin), end_(end) {}</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    I begin()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> begin_; }</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;    I end()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> end_; }</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    <span class="keywordtype">bool</span> em
 pty()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> begin_ == end_; }</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    </div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    I begin_, end_;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;};</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;} <span class="comment">// internal</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&
 #160;<span class="preprocessor">#endif // PROTON_ENDPOINT_HPP</span></div><div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
+<a href="endpoint_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ENDPOINT_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ENDPOINT_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor lice
 nse agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the
 </span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="error__condition_8hpp.html">./err
 or_condition.hpp</a>&quot;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno"><a class="line" href="classproton_1_1endpoint.html">   36</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00037
 "></a><span class="lineno">   37</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> ~<a class="code" href="classproton_1_1endpoint.html">endpoint</a>();</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;    <span class="comment">// XXX Add the container accessor here.</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;    </div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</s
 pan> = 0;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;    </div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> active() <span class="keyword">const</span> = 0;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;    </div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">bool</span> closed() <span class="keyword">const</span> = 0;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    <span class="keyword">virtual</span> <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const = 0;</div><div class="line"><a name="l00054"></a><sp
 an class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    <span class="comment">// XXX Add virtual open() and open(endpoint_options)</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;    </div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> close() = 0;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;) = 0;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno"> 
   67</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_DEFAULTED_FUNCTIONS &amp;&amp; PN_CPP_HAS_DEFAULTED_MOVE_INITIALIZERS</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    <span class="comment">// Make everything explicit for C++11 compilers</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>() = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp; operator=(<span class="keyword">const</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    <a class="c
 ode" href="classproton_1_1endpoint.html">endpoint</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp; operator=(<a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    <a class="code" href="classproton_1_1endpoint.html">endpoint</a>(<a class="code" href="classproton_1_1endpoint.html">endpoint</a>&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;};</div><div class="line"><
 a name="l00079"></a><span class="lineno">   79</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="keyword">namespace </span>internal {</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T, <span class="keyword">class</span> D&gt; <span class="keyword">class </span>iter_base {</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    <span class="keyword">typedef</span> T value_type;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    T operator*()<span class="keyword"> co
 nst </span>{ <span class="keywordflow">return</span> obj_; }</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    T* operator-&gt;()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> <span class="keyword">const_cast&lt;</span>T*<span class="keyword">&gt;</span>(&amp;obj_); }</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    D operator++(<span class="keywordtype">int</span>) { D x(*<span class="keyword">this</span>); ++(*this); <span class="keywordflow">return</span> x; }</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    <span class="keywordtype">bool</span> operator==(<span class="keyword">const</span> iter_base&lt;T, D&gt;&amp; x)<span class="keyword"> const </span>{ <span class="keywordflow">return</span> obj_ == x.obj_; }</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    <span class="keywordtype">bool</span> op
 erator!=(<span class="keyword">const</span> iter_base&lt;T, D&gt;&amp; x)<span class="keyword"> const </span>{ <span class="keywordflow">return</span> obj_ != x.obj_; }</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    </div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;  <span class="keyword">protected</span>:</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    <span class="keyword">explicit</span> iter_base(T p = 0) : obj_(p) {}</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    T obj_;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;};</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">class</span> I&gt; <span class="keyword">class 
 </span>iter_range {</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;    <span class="keyword">typedef</span> I iterator;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    <span class="keyword">explicit</span> iter_range(I begin = I(), I end = I()) : begin_(begin), end_(end) {}</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    I begin()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> begin_; }</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;    I end()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> end_; }</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>
 &#160;    <span class="keywordtype">bool</span> empty()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> begin_ == end_; }</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    </div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    I begin_, end_;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;};</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;} <span class="comment">// internal</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a na
 me="l00113"></a><span class="lineno">  113</span>&#160;<span class="preprocessor">#endif // PROTON_ENDPOINT_HPP</span></div><div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1endpoint_html"><div class="ttname"><a href="classproton_1_1endpoint.html">proton::endpoint</a></div><div class="ttdoc">The base class for session, connection, and link. </div><div class="ttdef"><b>Definition:</b> endpoint.hpp:36</div></div>
 <div class="ttc" id="error__condition_8hpp_html"><div class="ttname"><a href="error__condition_8hpp.html">error_condition.hpp</a></div><div class="ttdoc">Describes an endpoint error state. </div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/error__condition_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/error__condition_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/error__condition_8hpp_source.html
index d8e7c3b..82d7231 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/error__condition_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/error__condition_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('error__condition_8hpp_source.html','')
 <div class="title">error_condition.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="error__condition_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ERROR_CONDITION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ERROR_CONDITION_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or mor
 e contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   1
 3</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See t
 he License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name=
 "l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="value_8hpp.html">./value.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;iosfwd&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">struct </span>pn_condition_t;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160
 ;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno"><a class="line" href="classproton_1_1error__condition.html">   40</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> {</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(pn_condition_t* c);</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00047"></a><span class="lineno"><a class="line" href="classproton_1_1error__condition.html#a
 66ce60ce079e6a9446d8dad21b9a63bb">   47</a></span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>() {}</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string <a class="code" href="classproton_1_1error__condition.html#a07ffe70037e0a16554c868bcdd8f83b5">description</a>);</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string <a class="code" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb
 69367171">name</a>, std::string description);</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string name, std::string description, <a class="code" href="classproton_1_1value.html">proton::value</a> <a class="code" href="classproton_1_1error__condition.html#ac692ae9e7014e2ef47673c9201a98cf6">properties</a>);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_DEFAULTED_FUNCTIONS</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_conditio
 n</a>(<span class="keyword">const</span> error_condition&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(error_condition&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;    error_condition&amp; operator=(<span class="keyword">const</span> error_condition&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    error_condition&amp; operator=(error_condition&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</d
 iv><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_EXPLICIT_CONVERSIONS</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <span class="keyword">operator</span> bool() <span class="keyword">const</span>;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1error__condition.html#a61efd4196a96540ee018fee8791f3f10">operator!</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00080"></a><span
  class="lineno">   80</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1error__condition.html#a644718bb2fb240de962dc3c9a1fdf0dc">empty</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb69367171">name</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#a07ffe70037e0a16554c868bcdd8f83b5">description</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160
 ;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1value.html">value</a> <a class="code" href="classproton_1_1error__condition.html#ac692ae9e7014e2ef47673c9201a98cf6">properties</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">what</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    std::string name_;</div><div class="line"><a name="l0009
 6"></a><span class="lineno">   96</span>&#160;    std::string description_;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    <a class="code" href="classproton_1_1value.html">proton::value</a> properties_;</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;error_condition&gt;;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;};</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="comment">// XXX Document these </span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PN_CPP_EXTERN <span class="keywordtype">bool</span> operator==(<span class="keyword"
 >const</span> error_condition&amp; x, <span class="keyword">const</span> error_condition&amp; y);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;PN_CPP_EXTERN std::ostream&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(std::ostream&amp; o, <span class="keyword">const</span> error_condition&amp; err);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor">#endif // PROTON_ERROR_CONDITION_H</span></div><div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a href="namespaceproton.html#ae6fabe30961a3d3280bb8445e
 743b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
+<a href="error__condition_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_ERROR_CONDITION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_ERROR_CONDITION_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or mor
 e contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   1
 3</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See t
 he License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name=
 "l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="value_8hpp.html">./value.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;iosfwd&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">struct </span>pn_condition_t;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160
 ;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno"><a class="line" href="classproton_1_1error__condition.html">   40</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> {</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(pn_condition_t* c);</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00047"></a><span class="lineno"><a class="line" href="classproton_1_1error__condition.html#a
 66ce60ce079e6a9446d8dad21b9a63bb">   47</a></span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>() {}</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string <a class="code" href="classproton_1_1error__condition.html#a07ffe70037e0a16554c868bcdd8f83b5">description</a>);</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string <a class="code" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb
 69367171">name</a>, std::string description);</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(std::string name, std::string description, <a class="code" href="classproton_1_1value.html">proton::value</a> <a class="code" href="classproton_1_1error__condition.html#ac692ae9e7014e2ef47673c9201a98cf6">properties</a>);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_DEFAULTED_FUNCTIONS &amp;&amp; PN_CPP_HAS_DEFAULTED_MOVE_INITIALIZERS</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;    <a class="code" href="classproton_1_1error__condition.html
 #a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(<span class="keyword">const</span> error_condition&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;    error_condition&amp; operator=(<span class="keyword">const</span> error_condition&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;    <a class="code" href="classproton_1_1error__condition.html#a66ce60ce079e6a9446d8dad21b9a63bb">error_condition</a>(error_condition&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    error_condition&amp; operator=(error_condition&amp;&amp;) = <span class="keywordflow">default</span>;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l000
 68"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_EXPLICIT_CONVERSIONS</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <span class="keyword">operator</span> bool() <span class="keyword">const</span>;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1error__condition.html#a61efd4196a96540ee018fee8791f3f10">operator!</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;
 </div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1error__condition.html#a644718bb2fb240de962dc3c9a1fdf0dc">empty</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb69367171">name</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#a07ffe70037e0a16554c868bcdd8f83b5">description</a>() <span class="keyword">const</span>;</div><div class="line"><a name="
 l00087"></a><span class="lineno">   87</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1value.html">value</a> <a class="code" href="classproton_1_1error__condition.html#ac692ae9e7014e2ef47673c9201a98cf6">properties</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">what</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    std::s
 tring name_;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    std::string description_;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    <a class="code" href="classproton_1_1value.html">proton::value</a> properties_;</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;error_condition&gt;;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;};</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="comment">// XXX Document these </span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PN_CPP_EXTERN <span class="keyword
 type">bool</span> operator==(<span class="keyword">const</span> error_condition&amp; x, <span class="keyword">const</span> error_condition&amp; y);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;PN_CPP_EXTERN std::ostream&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(std::ostream&amp; o, <span class="keyword">const</span> error_condition&amp; err);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor">#endif // PROTON_ERROR_CONDITION_H</span></div><div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a hre
 f="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
 <div class="ttc" id="classproton_1_1error__condition_html_ad2e53bd52dbb1d59081ee7f9f1efc2ac"><div class="ttname"><a href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">proton::error_condition::what</a></div><div class="ttdeci">std::string what() const</div><div class="ttdoc">Simple printable string for condition. </div></div>
 <div class="ttc" id="classproton_1_1error__condition_html_a644718bb2fb240de962dc3c9a1fdf0dc"><div class="ttname"><a href="classproton_1_1error__condition.html#a644718bb2fb240de962dc3c9a1fdf0dc">proton::error_condition::empty</a></div><div class="ttdeci">bool empty() const</div><div class="ttdoc">No condition has been set. </div></div>
 <div class="ttc" id="classproton_1_1error__condition_html_a1d89c28bd42ba9a52da008bb69367171"><div class="ttname"><a href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb69367171">proton::error_condition::name</a></div><div class="ttdeci">std::string name() const</div><div class="ttdoc">Condition name. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/examples.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/examples.html b/content/releases/qpid-proton-master/proton/cpp/api/examples.html
index 2136a2e..62fdcb1 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/examples.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/examples.html
@@ -104,8 +104,6 @@ $(document).ready(function(){initNavTree('examples.html','');});
 
 <li><a class="el" href="helloworld_8cpp-example.html">helloworld.cpp</a></li>
 
-<li><a class="el" href="helloworld_direct_8cpp-example.html">helloworld_direct.cpp</a></li>
-
 <li><a class="el" href="message_properties_8cpp-example.html">message_properties.cpp</a></li>
 
 <li><a class="el" href="multithreaded_client_8cpp-example.html">multithreaded_client.cpp</a></li>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/examples.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/examples.js b/content/releases/qpid-proton-master/proton/cpp/api/examples.js
index cb2182f..24bb6b8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/examples.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/examples.js
@@ -5,7 +5,6 @@ var examples =
     [ "direct_recv.cpp", "direct_recv_8cpp-example.html", null ],
     [ "direct_send.cpp", "direct_send_8cpp-example.html", null ],
     [ "helloworld.cpp", "helloworld_8cpp-example.html", null ],
-    [ "helloworld_direct.cpp", "helloworld_direct_8cpp-example.html", null ],
     [ "message_properties.cpp", "message_properties_8cpp-example.html", null ],
     [ "multithreaded_client.cpp", "multithreaded_client_8cpp-example.html", null ],
     [ "multithreaded_client_flow_control.cpp", "multithreaded_client_flow_control_8cpp-example.html", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/export_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/export_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/export_8hpp_source.html
index bc952f1..f0f40df 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/export_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/export_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('export_8hpp_source.html','');});
 <div class="title">export.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_INTERNAL_EXPORT_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_INTERNAL_EXPORT_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div cl
 ass="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a na
 me="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><spa
 n class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#if defined(WIN32) &amp;&amp; !defined(PN_CPP_DECLARE_STATIC)</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00030"></a><
 span class="lineno">   30</span>&#160;  <span class="comment">// Import and Export definitions for Windows:</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __declspec(dllexport)</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT __declspec(dllimport)</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#elif defined(__SUNPRO_C) || define
 d(__SUNPRO_CC)</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __global</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT __global</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;  <span class="comment">// Non-Windows (Linux, etc.) defin
 itions:</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __attribute ((visibility (&quot;default&quot;)))</span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT __attribute ((visibility (&quot;default&quot;)))</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00050"></a><span class="lineno">  
  50</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment">// For qpid-proton-cpp library symbols</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="preprocessor">#ifdef qpid_proton_cpp_EXPORTS</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="preprocessor">#  define PN_CPP_EXTERN PN_CPP_EXPORT</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_EXPORT</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#  define PN_CPP_EXTERN PN_CPP_IMPORT</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#16
 0;<span class="preprocessor">#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#endif // PROTON_INTERNAL_EXPORT_HPP</span></div></div><!-- fragment --></div><!-- contents -->
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_INTERNAL_EXPORT_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_INTERNAL_EXPORT_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div cl
 ass="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a na
 me="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><spa
 n class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#if defined(WIN32) &amp;&amp; !defined(PN_CPP_DECLARE_STATIC)</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00030"></a><
 span class="lineno">   30</span>&#160;  <span class="comment">// Import and Export definitions for Windows:</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __declspec(dllexport)</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT __declspec(dllimport)</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#elif defined(__SUNPRO_C) || define
 d(__SUNPRO_CC)</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __global</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT __global</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;  <span class="comment">// Non-Windows (Linux, etc.) defin
 itions:</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="preprocessor">#  define PN_CPP_EXPORT __attribute__((visibility(&quot;default&quot;)))</span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="preprocessor">#  define PN_CPP_IMPORT</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXPORT __attribute__((visibility(&quot;default&quot;)))</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00050"></a><span class="lineno">  
  50</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment">// For qpid-proton-cpp library symbols</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="preprocessor">#ifdef qpid_proton_cpp_EXPORTS</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="preprocessor">#  define PN_CPP_EXTERN PN_CPP_EXPORT</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="preprocessor">#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_EXPORT</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#  define PN_CPP_EXTERN PN_CPP_IMPORT</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#16
 0;<span class="preprocessor">#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_IMPORT</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#if defined(PN_CPP_USE_DEPRECATED_API)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="preprocessor">#  define PN_CPP_DEPRECATED(message)</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor">#  if defined(PN_COMPILER_CXX_ATTRIBUTE_DEPRECATED) &amp;&amp; PN_COMPILER_CXX_ATTRIBUTE_DEPRECATED</span></div><div class="line"><a name="l00064"></a><span cla
 ss="lineno">   64</span>&#160;<span class="preprocessor">#    define PN_CPP_DEPRECATED(message) [[deprecated(message)]]</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#  elif defined(WIN32)</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#    define PN_CPP_DEPRECATED(message) __declspec(deprecated(message))</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#  elif (__GNUC__ * 10000 + __GNUC_MINOR__ * 100 + __GNUC_PATCHLEVEL__) &lt; 40500</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="preprocessor">#    define PN_CPP_DEPRECATED(message) __attribute__((deprecated))</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#  else</span></div><div class="line"><a name="l
 00070"></a><span class="lineno">   70</span>&#160;<span class="preprocessor">#    define PN_CPP_DEPRECATED(message) __attribute__((deprecated(message)))</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif // PROTON_INTERNAL_EXPORT_HPP</span></div></div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[49/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/codec_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/codec_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/codec_8h_source.html
index eee4404..b1768ef 100755
--- a/content/releases/qpid-proton-master/proton/c/api/codec_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/codec_8h_source.html
@@ -100,7 +100,7 @@ $(document).ready(function(){initNavTree('codec_8h_source.html','');});
 <div class="ttc" id="group__amqp__types_html_gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae"><div class="ttname"><a href="group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae">PN_DECIMAL64</a></div><div class="ttdoc">The decimal64 AMQP type. </div><div class="ttdef"><b>Definition:</b> codec.h:127</div></div>
 <div class="ttc" id="group__data_html_ga6cfb9e64b87f8d90a5b4237ca016a016"><div class="ttname"><a href="group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016">pn_data_put_int</a></div><div class="ttdeci">int pn_data_put_int(pn_data_t *data, int32_t i)</div><div class="ttdoc">Puts a PN_INT value. </div></div>
 <div class="ttc" id="group__data_html_ga61944d632d27ffc1c0d6348f62bfec4e"><div class="ttname"><a href="group__data.html#ga61944d632d27ffc1c0d6348f62bfec4e">pn_data_put_decimal128</a></div><div class="ttdeci">int pn_data_put_decimal128(pn_data_t *data, pn_decimal128_t d)</div><div class="ttdoc">Puts a PN_DECIMAL128 value. </div></div>
-<div class="ttc" id="group__amqp__types_html_ga54d49ca7ff04ad10a57139c2d61f1d44"><div class="ttname"><a href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a></div><div class="ttdeci">uint32_t pn_decimal32_t</div><div class="ttdoc">A 32-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:182</div></div>
+<div class="ttc" id="group__amqp__types_html_ga54d49ca7ff04ad10a57139c2d61f1d44"><div class="ttname"><a href="group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44">pn_decimal32_t</a></div><div class="ttdeci">uint32_t pn_decimal32_t</div><div class="ttdoc">A 32-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:180</div></div>
 <div class="ttc" id="group__data_html_ga4a35f7001de91101d78143e4e98e6556"><div class="ttname"><a href="group__data.html#ga4a35f7001de91101d78143e4e98e6556">pn_data_put_bool</a></div><div class="ttdeci">int pn_data_put_bool(pn_data_t *data, bool b)</div><div class="ttdoc">Puts a PN_BOOL value. </div></div>
 <div class="ttc" id="group__data_html_ga7672e15a4925bb14bebb79bc8206d392"><div class="ttname"><a href="group__data.html#ga7672e15a4925bb14bebb79bc8206d392">pn_data_put_decimal64</a></div><div class="ttdeci">int pn_data_put_decimal64(pn_data_t *data, pn_decimal64_t d)</div><div class="ttdoc">Puts a PN_DECIMAL64 value. </div></div>
 <div class="ttc" id="group__data_html_gae71bfb440cc4f0b15fe958bf55a3f6af"><div class="ttname"><a href="group__data.html#gae71bfb440cc4f0b15fe958bf55a3f6af">pn_data_encoded_size</a></div><div class="ttdeci">ssize_t pn_data_encoded_size(pn_data_t *data)</div><div class="ttdoc">Returns the number of bytes needed to encode a data object. </div></div>
@@ -111,11 +111,11 @@ $(document).ready(function(){initNavTree('codec_8h_source.html','');});
 <div class="ttc" id="group__data_html_gab3f699c30da99e02d13f773988e3849e"><div class="ttname"><a href="group__data.html#gab3f699c30da99e02d13f773988e3849e">pn_data_widen</a></div><div class="ttdeci">void pn_data_widen(pn_data_t *data)</div><div class="ttdoc">Reverse the effect of pn_data_narrow(). </div></div>
 <div class="ttc" id="group__data_html_gaeb8b424245ca352fb63dce8ca03cd8da"><div class="ttname"><a href="group__data.html#gaeb8b424245ca352fb63dce8ca03cd8da">pn_data_get_decimal128</a></div><div class="ttdeci">pn_decimal128_t pn_data_get_decimal128(pn_data_t *data)</div><div class="ttdoc">If the current node is a decimal128, returns its value, returns 0 otherwise. </div></div>
 <div class="ttc" id="group__data_html_gaac08905c5bfb2371951914e0fb2793b9"><div class="ttname"><a href="group__data.html#gaac08905c5bfb2371951914e0fb2793b9">pn_data_narrow</a></div><div class="ttdeci">void pn_data_narrow(pn_data_t *data)</div><div class="ttdoc">Modify a pn_data_t object to behave as if the current node is the root node of the tree...</div></div>
-<div class="ttc" id="group__amqp__types_html_structpn__uuid__t"><div class="ttname"><a href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a></div><div class="ttdoc">A 16-byte universally unique identifier. </div><div class="ttdef"><b>Definition:</b> types.h:205</div></div>
+<div class="ttc" id="group__amqp__types_html_structpn__uuid__t"><div class="ttname"><a href="group__amqp__types.html#structpn__uuid__t">pn_uuid_t</a></div><div class="ttdoc">A 16-byte universally unique identifier. </div><div class="ttdef"><b>Definition:</b> types.h:203</div></div>
 <div class="ttc" id="group__data_html_ga121070d2c21ef594f1cfe4083677f1a2"><div class="ttname"><a href="group__data.html#ga121070d2c21ef594f1cfe4083677f1a2">pn_data_put_double</a></div><div class="ttdeci">int pn_data_put_double(pn_data_t *data, double d)</div><div class="ttdoc">Puts a PN_DOUBLE value. </div></div>
 <div class="ttc" id="group__amqp__types_html_gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0"><div class="ttname"><a href="group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0">PN_FLOAT</a></div><div class="ttdoc">The float AMQP type. </div><div class="ttdef"><b>Definition:</b> codec.h:112</div></div>
 <div class="ttc" id="group__data_html_ga3af18fc419995766f83a4b4ac07c31ce"><div class="ttname"><a href="group__data.html#ga3af18fc419995766f83a4b4ac07c31ce">pn_data_get_list</a></div><div class="ttdeci">size_t pn_data_get_list(pn_data_t *data)</div><div class="ttdoc">If the current node is a list, return the number of elements, otherwise return zero. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__atom__t"><div class="ttname"><a href="group__api__types.html#structpn__atom__t">pn_atom_t</a></div><div class="ttdoc">A descriminated union that holds any scalar AMQP value. </div><div class="ttdef"><b>Definition:</b> codec.h:200</div></div>
+<div class="ttc" id="group__api__types_html_structpn__atom__t"><div class="ttname"><a href="group__api__types.html#structpn__atom__t">pn_atom_t</a></div><div class="ttdoc">A discriminated union that holds any scalar AMQP value. </div><div class="ttdef"><b>Definition:</b> codec.h:200</div></div>
 <div class="ttc" id="group__amqp__types_html_gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13"><div class="ttname"><a href="group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13">PN_UUID</a></div><div class="ttdoc">The UUID AMQP type. </div><div class="ttdef"><b>Definition:</b> codec.h:137</div></div>
 <div class="ttc" id="group__data_html_gabf41ef79c9a4f7e3fd673b0999e63a41"><div class="ttname"><a href="group__data.html#gabf41ef79c9a4f7e3fd673b0999e63a41">pn_data_get_float</a></div><div class="ttdeci">float pn_data_get_float(pn_data_t *data)</div><div class="ttdoc">If the current node is a float, returns its value, raises 0 otherwise. </div></div>
 <div class="ttc" id="group__amqp__types_html_gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe"><div class="ttname"><a href="group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe">PN_NULL</a></div><div class="ttdoc">The NULL AMQP type. </div><div class="ttdef"><b>Definition:</b> codec.h:51</div></div>
@@ -156,14 +156,14 @@ $(document).ready(function(){initNavTree('codec_8h_source.html','');});
 <div class="ttc" id="group__data_html_ga26d61fd9b512c322344d410384202005"><div class="ttname"><a href="group__data.html#ga26d61fd9b512c322344d410384202005">pn_data_rewind</a></div><div class="ttdeci">void pn_data_rewind(pn_data_t *data)</div><div class="ttdoc">Clears current node pointer and sets the parent to the root node. </div></div>
 <div class="ttc" id="group__data_html_gabdbfa1e913c490d3b1ad6ca169910482"><div class="ttname"><a href="group__data.html#gabdbfa1e913c490d3b1ad6ca169910482">pn_data_get_decimal32</a></div><div class="ttdeci">pn_decimal32_t pn_data_get_decimal32(pn_data_t *data)</div><div class="ttdoc">If the current node is a decimal32, returns its value, returns 0 otherwise. </div></div>
 <div class="ttc" id="group__data_html_gab230cca5089c6c28c4c12d507513fde9"><div class="ttname"><a href="group__data.html#gab230cca5089c6c28c4c12d507513fde9">pn_data_put_short</a></div><div class="ttdeci">int pn_data_put_short(pn_data_t *data, int16_t s)</div><div class="ttdoc">Puts a PN_SHORT value. </div></div>
-<div class="ttc" id="group__amqp__types_html_structpn__decimal128__t"><div class="ttname"><a href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a></div><div class="ttdoc">A 128-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:196</div></div>
+<div class="ttc" id="group__amqp__types_html_structpn__decimal128__t"><div class="ttname"><a href="group__amqp__types.html#structpn__decimal128__t">pn_decimal128_t</a></div><div class="ttdoc">A 128-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:194</div></div>
 <div class="ttc" id="group__data_html_ga20dda5db37c55c12b28e428c311b79da"><div class="ttname"><a href="group__data.html#ga20dda5db37c55c12b28e428c311b79da">pn_data_put_array</a></div><div class="ttdeci">int pn_data_put_array(pn_data_t *data, bool described, pn_type_t type)</div><div class="ttdoc">Puts an empty array value into a pn_data_t. </div></div>
 <div class="ttc" id="group__data_html_gaee6e7a4f78d202cc81657e3976fd68ae"><div class="ttname"><a href="group__data.html#gaee6e7a4f78d202cc81657e3976fd68ae">pn_data_get_binary</a></div><div class="ttdeci">pn_bytes_t pn_data_get_binary(pn_data_t *data)</div><div class="ttdoc">If the current node is binary, returns its value, returns &quot;&quot; otherwise. </div></div>
-<div class="ttc" id="group__data_html_gada171f4740e6a1132b4d4b9c0aea645c"><div class="ttname"><a href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">pn_data_error</a></div><div class="ttdeci">pn_error_t * pn_data_error(pn_data_t *data)</div><div class="ttdoc">Access the current error for a givn pn_data_t. </div></div>
+<div class="ttc" id="group__data_html_gada171f4740e6a1132b4d4b9c0aea645c"><div class="ttname"><a href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">pn_data_error</a></div><div class="ttdeci">pn_error_t * pn_data_error(pn_data_t *data)</div><div class="ttdoc">Access the current error for a given pn_data_t. </div></div>
 <div class="ttc" id="group__data_html_gac5d5c6e6bf24597caf63d35b1755e646"><div class="ttname"><a href="group__data.html#gac5d5c6e6bf24597caf63d35b1755e646">pn_data_get_atom</a></div><div class="ttdeci">pn_atom_t pn_data_get_atom(pn_data_t *data)</div><div class="ttdoc">If the current node is a scalar value, return it as a pn_atom_t. </div></div>
 <div class="ttc" id="group__data_html_gafccb5008960eb8dc757cb7f9941e5013"><div class="ttname"><a href="group__data.html#gafccb5008960eb8dc757cb7f9941e5013">pn_data_get_string</a></div><div class="ttdeci">pn_bytes_t pn_data_get_string(pn_data_t *data)</div><div class="ttdoc">If the current node is a string, returns its value, returns &quot;&quot; otherwise. </div></div>
 <div class="ttc" id="group__data_html_ga2c02eee58084ba9b77a37c086e195802"><div class="ttname"><a href="group__data.html#ga2c02eee58084ba9b77a37c086e195802">pn_data_free</a></div><div class="ttdeci">void pn_data_free(pn_data_t *data)</div><div class="ttdoc">Free a pn_data_t object. </div></div>
-<div class="ttc" id="group__amqp__types_html_ga7d8110bc953738d83ad8b9c543ef517f"><div class="ttname"><a href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a></div><div class="ttdeci">uint64_t pn_decimal64_t</div><div class="ttdoc">A 64-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:189</div></div>
+<div class="ttc" id="group__amqp__types_html_ga7d8110bc953738d83ad8b9c543ef517f"><div class="ttname"><a href="group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f">pn_decimal64_t</a></div><div class="ttdeci">uint64_t pn_decimal64_t</div><div class="ttdoc">A 64-bit decimal floating-point number. </div><div class="ttdef"><b>Definition:</b> types.h:187</div></div>
 <div class="ttc" id="group__data_html_ga3c64a188867ebb19c8d4e3908e6f8e20"><div class="ttname"><a href="group__data.html#ga3c64a188867ebb19c8d4e3908e6f8e20">pn_data_get_symbol</a></div><div class="ttdeci">pn_bytes_t pn_data_get_symbol(pn_data_t *data)</div><div class="ttdoc">If the current node is a symbol, returns its value, returns &quot;&quot; otherwise. </div></div>
 <div class="ttc" id="group__data_html_gacb2c0b2c56d587ee354aaa0f21f2c9b1"><div class="ttname"><a href="group__data.html#gacb2c0b2c56d587ee354aaa0f21f2c9b1">pn_data_put_timestamp</a></div><div class="ttdeci">int pn_data_put_timestamp(pn_data_t *data, pn_timestamp_t t)</div><div class="ttdoc">Puts a PN_TIMESTAMP value. </div></div>
 <div class="ttc" id="group__data_html_ga549ee35ecd73ac55e9e8aa196a6ba2ec"><div class="ttname"><a href="group__data.html#ga549ee35ecd73ac55e9e8aa196a6ba2ec">pn_data_put_uint</a></div><div class="ttdeci">int pn_data_put_uint(pn_data_t *data, uint32_t ui)</div><div class="ttdoc">Puts a PN_UINT value. </div></div>
@@ -175,7 +175,7 @@ $(document).ready(function(){initNavTree('codec_8h_source.html','');});
 <div class="ttc" id="group__data_html_ga74430b712be334a05861cfd5e9b312b9"><div class="ttname"><a href="group__data.html#ga74430b712be334a05861cfd5e9b312b9">pn_data_decode</a></div><div class="ttdeci">ssize_t pn_data_decode(pn_data_t *data, const char *bytes, size_t size)</div><div class="ttdoc">Decodes a single value from the contents of the AMQP data stream into the current data object...</div></div>
 <div class="ttc" id="group__data_html_ga9a048cfd78ca76604b667d170eac0136"><div class="ttname"><a href="group__data.html#ga9a048cfd78ca76604b667d170eac0136">pn_data_appendn</a></div><div class="ttdeci">int pn_data_appendn(pn_data_t *data, pn_data_t *src, int limit)</div><div class="ttdoc">Append up to n values from the contents of another pn_data_t object. </div></div>
 <div class="ttc" id="group__data_html_ga0199029f44d9c86e469c15bef51ceea2"><div class="ttname"><a href="group__data.html#ga0199029f44d9c86e469c15bef51ceea2">pn_data_put_decimal32</a></div><div class="ttdeci">int pn_data_put_decimal32(pn_data_t *data, pn_decimal32_t d)</div><div class="ttdoc">Puts a PN_DECIMAL32 value. </div></div>
-<div class="ttc" id="group__amqp__types_html_gaa1713f25d484600197d2a25ace856672"><div class="ttname"><a href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a></div><div class="ttdeci">uint32_t pn_char_t</div><div class="ttdoc">A 32-bit Unicode code point. </div><div class="ttdef"><b>Definition:</b> types.h:175</div></div>
+<div class="ttc" id="group__amqp__types_html_gaa1713f25d484600197d2a25ace856672"><div class="ttname"><a href="group__amqp__types.html#gaa1713f25d484600197d2a25ace856672">pn_char_t</a></div><div class="ttdeci">uint32_t pn_char_t</div><div class="ttdoc">A 32-bit Unicode code point. </div><div class="ttdef"><b>Definition:</b> types.h:173</div></div>
 <div class="ttc" id="group__data_html_gadbd4c895a1e10266d20898996ce53bc0"><div class="ttname"><a href="group__data.html#gadbd4c895a1e10266d20898996ce53bc0">pn_data_get_map</a></div><div class="ttdeci">size_t pn_data_get_map(pn_data_t *data)</div><div class="ttdoc">If the current node is a map, return the number of child elements, otherwise return zero...</div></div>
 <div class="ttc" id="group__data_html_gab0f8eefe5f89362ffe186a092044d936"><div class="ttname"><a href="group__data.html#gab0f8eefe5f89362ffe186a092044d936">pn_data_get_array</a></div><div class="ttdeci">size_t pn_data_get_array(pn_data_t *data)</div><div class="ttdoc">If the current node is an array, return the number of elements in the array, otherwise return 0...</div></div>
 <div class="ttc" id="group__amqp__types_html_ga48a3094a983392e095984f1db2ec4fe3"><div class="ttname"><a href="group__amqp__types.html#ga48a3094a983392e095984f1db2ec4fe3">pn_type_name</a></div><div class="ttdeci">const char * pn_type_name(pn_type_t type)</div><div class="ttdoc">Return a string name for an AMQP type. </div></div>
@@ -206,10 +206,10 @@ $(document).ready(function(){initNavTree('codec_8h_source.html','');});
 <div class="ttc" id="group__data_html_ga5502724bcde68615bc47e09a3335b527"><div class="ttname"><a href="group__data.html#ga5502724bcde68615bc47e09a3335b527">pn_data_encode</a></div><div class="ttdeci">ssize_t pn_data_encode(pn_data_t *data, char *bytes, size_t size)</div><div class="ttdoc">Writes the contents of a data object to the given buffer as an AMQP data stream. </div></div>
 <div class="ttc" id="group__data_html_gabba00ce3862818acd8ca91c2a8af348b"><div class="ttname"><a href="group__data.html#gabba00ce3862818acd8ca91c2a8af348b">pn_data_is_null</a></div><div class="ttdeci">bool pn_data_is_null(pn_data_t *data)</div><div class="ttdoc">Checks if the current node is a PN_NULL. </div></div>
 <div class="ttc" id="group__data_html_ga0a98b8f17784460034c240ed4b6b47d7"><div class="ttname"><a href="group__data.html#ga0a98b8f17784460034c240ed4b6b47d7">pn_data_append</a></div><div class="ttdeci">int pn_data_append(pn_data_t *data, pn_data_t *src)</div><div class="ttdoc">Append the contents of another pn_data_t object. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:214</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
 <div class="ttc" id="group__data_html_ga49df9ede673853123d84861c169d6113"><div class="ttname"><a href="group__data.html#ga49df9ede673853123d84861c169d6113">pn_data_put_ubyte</a></div><div class="ttdeci">int pn_data_put_ubyte(pn_data_t *data, uint8_t ub)</div><div class="ttdoc">Puts a PN_UBYTE value. </div></div>
 <div class="ttc" id="group__api__types_html_a27df760d7bd97cf728fc3e633a1ba604"><div class="ttname"><a href="group__api__types.html#a27df760d7bd97cf728fc3e633a1ba604">pn_atom_t::type</a></div><div class="ttdeci">pn_type_t type</div><div class="ttdoc">Indicates the type of value the atom is currently pointing to. </div><div class="ttdef"><b>Definition:</b> codec.h:205</div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:168</div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 <div class="ttc" id="group__data_html_ga182347d1d444bf6290b39239c4c13d0f"><div class="ttname"><a href="group__data.html#ga182347d1d444bf6290b39239c4c13d0f">pn_data_put_byte</a></div><div class="ttdeci">int pn_data_put_byte(pn_data_t *data, int8_t b)</div><div class="ttdoc">Puts a PN_BYTE value. </div></div>
 <div class="ttc" id="group__data_html_gad7fac25ba5589ff0374442cf7ecbbd9c"><div class="ttname"><a href="group__data.html#gad7fac25ba5589ff0374442cf7ecbbd9c">pn_data_is_described</a></div><div class="ttdeci">bool pn_data_is_described(pn_data_t *data)</div><div class="ttdoc">Checks if the current node is a described value. </div></div>
 <div class="ttc" id="group__data_html_ga926c8732c66f38f3b9578d50af30f2ff"><div class="ttname"><a href="group__data.html#ga926c8732c66f38f3b9578d50af30f2ff">pn_data_put_atom</a></div><div class="ttdeci">int pn_data_put_atom(pn_data_t *data, pn_atom_t atom)</div><div class="ttdoc">Puts any scalar value value. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/connection_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/connection_8h.html b/content/releases/qpid-proton-master/proton/c/api/connection_8h.html
index 9a7e8fd..0dea9d6 100755
--- a/content/releases/qpid-proton-master/proton/c/api/connection_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/connection_8h.html
@@ -156,6 +156,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga7c88b4833cf81d801b27d00b45d137b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Release a connection object.  <a href="group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5">More...</a><br /></td></tr>
 <tr class="separator:ga7c88b4833cf81d801b27d00b45d137b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad3aad758ccb4690e78d40c1a73567d73"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:gad3aad758ccb4690e78d40c1a73567d73"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">More...</a><br /></td></tr>
 <tr class="separator:gad3aad758ccb4690e78d40c1a73567d73"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2fd2089e8eaa2a362606498f233ada61"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">pn_connection_collect</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector)</td></tr>
 <tr class="memdesc:ga2fd2089e8eaa2a362606498f233ada61"><td class="mdescLeft">&#160;</td><td class="mdescRight">Associate a connection object with an event collector.  <a href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">More...</a><br /></td></tr>
@@ -164,8 +165,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga663c29ee6de4d522ba061224bc6240ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the collector set with <a class="el" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61" title="Associate a connection object with an event collector. ">pn_connection_collect()</a>  <a href="group__connection.html#ga663c29ee6de4d522ba061224bc6240ad">More...</a><br /></td></tr>
 <tr class="separator:ga663c29ee6de4d522ba061224bc6240ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga50613e6c09186dc3f1a2f36238c61f07"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:ga50613e6c09186dc3f1a2f36238c61f07"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>.  <a href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">More...</a><br /></td></tr>
 <tr class="separator:ga50613e6c09186dc3f1a2f36238c61f07"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, void *context)</td></tr>
+<tr class="memdesc:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da" title="Get the attachments that are associated with a connection object. ">pn_connection_attachments()</a>.  <a href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">More...</a><br /></td></tr>
 <tr class="separator:gad3203b366cb1ff5becd1778a8dd6b1a6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad8b6c777b525c9da9401e3a770db15da"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">pn_connection_attachments</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:gad8b6c777b525c9da9401e3a770db15da"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a connection object.  <a href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">More...</a><br /></td></tr>
@@ -225,10 +228,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:gac26de255ed04e73295d6aa973a663142"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access/modify the AMQP properties data for a connection object.  <a href="group__connection.html#gac26de255ed04e73295d6aa973a663142">More...</a><br /></td></tr>
 <tr class="separator:gac26de255ed04e73295d6aa973a663142"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga9bf90f0f395d26e320293063b70d040f"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
-<tr class="memdesc:ga9bf90f0f395d26e320293063b70d040f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP offered capabilites supplied by the remote connection endpoint.  <a href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">More...</a><br /></td></tr>
+<tr class="memdesc:ga9bf90f0f395d26e320293063b70d040f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP offered capabilities supplied by the remote connection endpoint.  <a href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">More...</a><br /></td></tr>
 <tr class="separator:ga9bf90f0f395d26e320293063b70d040f"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga722d53b6063278fbcab5f814613c70ec"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
-<tr class="memdesc:ga722d53b6063278fbcab5f814613c70ec"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP desired capabilites supplied by the remote connection endpoint.  <a href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">More...</a><br /></td></tr>
+<tr class="memdesc:ga722d53b6063278fbcab5f814613c70ec"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP desired capabilities supplied by the remote connection endpoint.  <a href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">More...</a><br /></td></tr>
 <tr class="separator:ga722d53b6063278fbcab5f814613c70ec"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga24a2d5aba432db549257993bfaa761dd"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">pn_connection_remote_properties</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:ga24a2d5aba432db549257993bfaa761dd"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the AMQP connection properties supplied by the remote connection endpoint.  <a href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">More...</a><br /></td></tr>


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


[48/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/connection_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/connection_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/connection_8h_source.html
index 3ca1df2..c91e285 100755
--- a/content/releases/qpid-proton-master/proton/c/api/connection_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/connection_8h_source.html
@@ -93,24 +93,24 @@ $(document).ready(function(){initNavTree('connection_8h_source.html','');});
 <div class="title">connection.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="connection_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor li
 cense agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<s
 pan class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for t
 he</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="codec_8h.html">proton/codec.h</a>&gt;</span></div><div class="lin
 e"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00033"></a><span class="
 lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61">   50</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_UNINIT (1)</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa
 2b">   55</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_ACTIVE (2)</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno"><a class="line" href="group__connection.html#ga602c2c870ebed1d9bfe100876909225b">   60</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_CLOSED (4)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno"><a class="line" href="group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3">   65</a></span>&#160;<span class="preprocessor">#define PN_REMOTE_UNINIT (8)</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno"><a class="line" href="group__connection.html#gad96220f2886c21a4f2eebc9487f53a87">   70</a></span>&#160;<span class="preprocessor">#
 define PN_REMOTE_ACTIVE (16)</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno"><a class="line" href="group__connection.html#ga764c602a20457f9aa8862825b6d13a8d">   75</a></span>&#160;<span class="preprocessor">#define PN_REMOTE_CLOSED (32)</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno"><a class="line" href="group__connection.html#ga32329c4bb3e23607a243cd8100c01264">   81</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_MASK (PN_LOCAL_UNINIT | PN_LOCAL_ACTIVE | PN_LOCAL_CLOSED)</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno"><a class="line" href="group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3">   87</a></span>&#160;<span class="preprocessor">#def
 ine PN_REMOTE_MASK (PN_REMOTE_UNINIT | PN_REMOTE_ACTIVE | PN_REMOTE_CLOSED)</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&
 #160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e">pn_connection_free</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5">pn_connection_release</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;PN_EXTERN <a class="code" href="group
 __error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">pn_connection_collect</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;P
 N_EXTERN <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a>* <a class="code" href="group__connection.html#ga663c29ee6de4d522ba061224bc6240ad">pn_connection_collector</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="c
 ode" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">pn_connection_attachments</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__connection.html#
 ga277d01dc2f87870ee260d43cf40abe13">pn_connection_state</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a
 206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3">pn_connection_reset</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__connection.html#gaace04a030192f34747bb1ff3675c58f1">pn_connection_condition</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div clas
 s="line"><a name="l00256"></a><span class="lineno">  256</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00283"></a><span class="lineno">  283</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga61e1f6386d18a568da50b998200eb87b">pn_connection_get_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><
 a name="l00284"></a><span class="lineno">  284</span>&#160;</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *container);</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gafb84dd2ef7551ad864be08cb31010d19">pn_connection_set_user</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordt
 ype">char</span> *user);</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285">pn_connection_set_password</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00323"></a><span class="lineno">  323</span>&#160;</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8">pn_connection_get_user</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_con
 nection_t</a> *connection);</div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;</div><div class="line"><a name="l00342"></a><span class="lineno">  342</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c">pn_connection_get_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00343"></a><span class="lineno">  343</span>&#160;</div><div class="line"><a name="l00357"></a><span class="lineno">  357</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb">pn_connection_set_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="ke
 ywordtype">char</span> *hostname);</div><div class="line"><a name="l00358"></a><span class="lineno">  358</span>&#160;</div><div class="line"><a name="l00373"></a><span class="lineno">  373</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a">pn_connection_remote_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00374"></a><span class="lineno">  374</span>&#160;</div><div class="line"><a name="l00388"></a><span class="lineno">  388</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#gabf25d7b763951b4a9c856536d6db0600">pn_connection_remote_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);
 </div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;</div><div class="line"><a name="l00406"></a><span class="lineno">  406</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#gabc8d505108a850837a0d2fb204875390">pn_connection_offered_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00407"></a><span class="lineno">  407</span>&#160;</div><div class="line"><a name="l00424"></a><span class="lineno">  424</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8">pn_connection_desired_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *conne
 ction);</div><div class="line"><a name="l00425"></a><span class="lineno">  425</span>&#160;</div><div class="line"><a name="l00441"></a><span class="lineno">  441</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#gac26de255ed04e73295d6aa973a663142">pn_connection_properties</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00442"></a><span class="lineno">  442</span>&#160;</div><div class="line"><a name="l00455"></a><span class="lineno">  455</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c
 onnection);</div><div class="line"><a name="l00456"></a><span class="lineno">  456</span>&#160;</div><div class="line"><a name="l00469"></a><span class="lineno">  469</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00470"></a><span class="lineno">  470</span>&#160;</div><div class="line"><a name="l00483"></a><span class="lineno">  483</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">pn_connection_remote_properties</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connecti
 on_t</a> *connection);</div><div class="line"><a name="l00484"></a><span class="lineno">  484</span>&#160;</div><div class="line"><a name="l00494"></a><span class="lineno">  494</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *<a class="code" href="group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59">pn_connection_transport</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00495"></a><span class="lineno">  495</span>&#160;</div><div class="line"><a name="l00500"></a><span class="lineno">  500</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00501"></a><span class="lineno">  501</span>&#160;}</div><div class="line"><a name="l00502"></a><span class="lineno">  502</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00503"></a>
 <span class="lineno">  503</span>&#160;</div><div class="line"><a name="l00504"></a><span class="lineno">  504</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* connection.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__connection_html_ga50613e6c09186dc3f1a2f36238c61f07"><div class="ttname"><a href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a></div><div class="ttdeci">void * pn_connection_get_context(pn_connection_t *connection)</div></div>
+<a href="connection_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor li
 cense agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<s
 pan class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for t
 he</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="codec_8h.html">proton/codec.h</a>&gt;</span></div><div class="lin
 e"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="error_8h.html">proton/error.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00033"></a><span class="
 lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61">   50</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_UNINIT (1)</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa
 2b">   55</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_ACTIVE (2)</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno"><a class="line" href="group__connection.html#ga602c2c870ebed1d9bfe100876909225b">   60</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_CLOSED (4)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno"><a class="line" href="group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3">   65</a></span>&#160;<span class="preprocessor">#define PN_REMOTE_UNINIT (8)</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno"><a class="line" href="group__connection.html#gad96220f2886c21a4f2eebc9487f53a87">   70</a></span>&#160;<span class="preprocessor">#
 define PN_REMOTE_ACTIVE (16)</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno"><a class="line" href="group__connection.html#ga764c602a20457f9aa8862825b6d13a8d">   75</a></span>&#160;<span class="preprocessor">#define PN_REMOTE_CLOSED (32)</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno"><a class="line" href="group__connection.html#ga32329c4bb3e23607a243cd8100c01264">   81</a></span>&#160;<span class="preprocessor">#define PN_LOCAL_MASK (PN_LOCAL_UNINIT | PN_LOCAL_ACTIVE | PN_LOCAL_CLOSED)</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno"><a class="line" href="group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3">   87</a></span>&#160;<span class="preprocessor">#def
 ine PN_REMOTE_MASK (PN_REMOTE_UNINIT | PN_REMOTE_ACTIVE | PN_REMOTE_CLOSED)</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&
 #160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e">pn_connection_free</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5">pn_connection_release</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;PN_EXTERN <a class="code" href="group
 __error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">pn_connection_collect</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;P
 N_EXTERN <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a>* <a class="code" href="group__connection.html#ga663c29ee6de4d522ba061224bc6240ad">pn_connection_collector</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="c
 ode" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">pn_connection_attachments</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__connection.html#
 ga277d01dc2f87870ee260d43cf40abe13">pn_connection_state</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a
 206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3">pn_connection_reset</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__connection.html#gaace04a030192f34747bb1ff3675c58f1">pn_connection_condition</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div clas
 s="line"><a name="l00256"></a><span class="lineno">  256</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00283"></a><span class="lineno">  283</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga61e1f6386d18a568da50b998200eb87b">pn_connection_get_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><
 a name="l00284"></a><span class="lineno">  284</span>&#160;</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *container);</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#gafb84dd2ef7551ad864be08cb31010d19">pn_connection_set_user</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordt
 ype">char</span> *user);</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285">pn_connection_set_password</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00323"></a><span class="lineno">  323</span>&#160;</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8">pn_connection_get_user</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_con
 nection_t</a> *connection);</div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;</div><div class="line"><a name="l00342"></a><span class="lineno">  342</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c">pn_connection_get_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00343"></a><span class="lineno">  343</span>&#160;</div><div class="line"><a name="l00357"></a><span class="lineno">  357</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb">pn_connection_set_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="ke
 ywordtype">char</span> *hostname);</div><div class="line"><a name="l00358"></a><span class="lineno">  358</span>&#160;</div><div class="line"><a name="l00373"></a><span class="lineno">  373</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a">pn_connection_remote_container</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00374"></a><span class="lineno">  374</span>&#160;</div><div class="line"><a name="l00388"></a><span class="lineno">  388</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__connection.html#gabf25d7b763951b4a9c856536d6db0600">pn_connection_remote_hostname</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);
 </div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;</div><div class="line"><a name="l00406"></a><span class="lineno">  406</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#gabc8d505108a850837a0d2fb204875390">pn_connection_offered_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00407"></a><span class="lineno">  407</span>&#160;</div><div class="line"><a name="l00424"></a><span class="lineno">  424</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8">pn_connection_desired_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *conne
 ction);</div><div class="line"><a name="l00425"></a><span class="lineno">  425</span>&#160;</div><div class="line"><a name="l00441"></a><span class="lineno">  441</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#gac26de255ed04e73295d6aa973a663142">pn_connection_properties</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00442"></a><span class="lineno">  442</span>&#160;</div><div class="line"><a name="l00455"></a><span class="lineno">  455</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c
 onnection);</div><div class="line"><a name="l00456"></a><span class="lineno">  456</span>&#160;</div><div class="line"><a name="l00469"></a><span class="lineno">  469</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00470"></a><span class="lineno">  470</span>&#160;</div><div class="line"><a name="l00483"></a><span class="lineno">  483</span>&#160;PN_EXTERN <a class="code" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *<a class="code" href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">pn_connection_remote_properties</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connecti
 on_t</a> *connection);</div><div class="line"><a name="l00484"></a><span class="lineno">  484</span>&#160;</div><div class="line"><a name="l00494"></a><span class="lineno">  494</span>&#160;PN_EXTERN <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *<a class="code" href="group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59">pn_connection_transport</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00495"></a><span class="lineno">  495</span>&#160;</div><div class="line"><a name="l00500"></a><span class="lineno">  500</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00501"></a><span class="lineno">  501</span>&#160;}</div><div class="line"><a name="l00502"></a><span class="lineno">  502</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00503"></a>
 <span class="lineno">  503</span>&#160;</div><div class="line"><a name="l00504"></a><span class="lineno">  504</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* connection.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__connection_html_ga50613e6c09186dc3f1a2f36238c61f07"><div class="ttname"><a href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a></div><div class="ttdeci">void * pn_connection_get_context(pn_connection_t *connection)</div><div class="ttdoc">Deprecated - Use pn_connection_attachments(). </div></div>
 <div class="ttc" id="group__connection_html_ga24a2d5aba432db549257993bfaa761dd"><div class="ttname"><a href="group__connection.html#ga24a2d5aba432db549257993bfaa761dd">pn_connection_remote_properties</a></div><div class="ttdeci">pn_data_t * pn_connection_remote_properties(pn_connection_t *connection)</div><div class="ttdoc">Access the AMQP connection properties supplied by the remote connection endpoint. ...</div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
 <div class="ttc" id="group__connection_html_ga72a362389b99d8e891bf2e4fb4290754"><div class="ttname"><a href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a></div><div class="ttdeci">pn_condition_t * pn_connection_remote_condition(pn_connection_t *connection)</div><div class="ttdoc">Get the remote condition associated with the connection endpoint. </div></div>
 <div class="ttc" id="group__connection_html_ga277d01dc2f87870ee260d43cf40abe13"><div class="ttname"><a href="group__connection.html#ga277d01dc2f87870ee260d43cf40abe13">pn_connection_state</a></div><div class="ttdeci">pn_state_t pn_connection_state(pn_connection_t *connection)</div><div class="ttdoc">Get the endpoint state flags for a connection. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="codec_8h_html"><div class="ttname"><a href="codec_8h.html">codec.h</a></div><div class="ttdoc">AMQP data encoding and decoding. </div></div>
-<div class="ttc" id="group__connection_html_ga722d53b6063278fbcab5f814613c70ec"><div class="ttname"><a href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_remote_desired_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access the AMQP desired capabilites supplied by the remote connection endpoint. </div></div>
+<div class="ttc" id="group__connection_html_ga722d53b6063278fbcab5f814613c70ec"><div class="ttname"><a href="group__connection.html#ga722d53b6063278fbcab5f814613c70ec">pn_connection_remote_desired_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_remote_desired_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access the AMQP desired capabilities supplied by the remote connection endpoint. </div></div>
 <div class="ttc" id="group__connection_html_gabb5b585ee8bae0e88d2b42b87772082a"><div class="ttname"><a href="group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a">pn_connection_remote_container</a></div><div class="ttdeci">const char * pn_connection_remote_container(pn_connection_t *connection)</div><div class="ttdoc">Get the AMQP Container name advertised by the remote connection endpoint. </div></div>
 <div class="ttc" id="group__error_html_ga24a289d5b32c9bd8a775600a5af83d52"><div class="ttname"><a href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a></div><div class="ttdeci">struct pn_error_t pn_error_t</div><div class="ttdoc">An int error code and some string text to describe the error. </div><div class="ttdef"><b>Definition:</b> error.h:44</div></div>
 <div class="ttc" id="group__connection_html_gafb84dd2ef7551ad864be08cb31010d19"><div class="ttname"><a href="group__connection.html#gafb84dd2ef7551ad864be08cb31010d19">pn_connection_set_user</a></div><div class="ttdeci">void pn_connection_set_user(pn_connection_t *connection, const char *user)</div><div class="ttdoc">Set the authentication username for a client connection. </div></div>
-<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:415</div></div>
+<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
 <div class="ttc" id="error_8h_html"><div class="ttname"><a href="error_8h.html">error.h</a></div><div class="ttdoc">A Proton API error. </div></div>
 <div class="ttc" id="group__connection_html_ga241faafc5a98cf9b91aa919263bd9bd8"><div class="ttname"><a href="group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8">pn_connection_desired_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_desired_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access/modify the AMQP desired capabilities data for a connection object. </div></div>
 <div class="ttc" id="group__connection_html_ga00cbef1a9f5062a6e1f113fda923f65e"><div class="ttname"><a href="group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e">pn_connection_free</a></div><div class="ttdeci">void pn_connection_free(pn_connection_t *connection)</div><div class="ttdoc">Free a connection object. </div></div>
 <div class="ttc" id="condition_8h_html"><div class="ttname"><a href="condition_8h.html">condition.h</a></div><div class="ttdoc">An endpoint error state. </div></div>
 <div class="ttc" id="group__connection_html_gaace04a030192f34747bb1ff3675c58f1"><div class="ttname"><a href="group__connection.html#gaace04a030192f34747bb1ff3675c58f1">pn_connection_condition</a></div><div class="ttdeci">pn_condition_t * pn_connection_condition(pn_connection_t *connection)</div><div class="ttdoc">Get the local condition associated with the connection endpoint. </div></div>
-<div class="ttc" id="group__connection_html_gad3203b366cb1ff5becd1778a8dd6b1a6"><div class="ttname"><a href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a></div><div class="ttdeci">void pn_connection_set_context(pn_connection_t *connection, void *context)</div></div>
+<div class="ttc" id="group__connection_html_gad3203b366cb1ff5becd1778a8dd6b1a6"><div class="ttname"><a href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a></div><div class="ttdeci">void pn_connection_set_context(pn_connection_t *connection, void *context)</div><div class="ttdoc">Deprecated - Use pn_connection_attachments(). </div></div>
 <div class="ttc" id="group__connection_html_ga61e1f6386d18a568da50b998200eb87b"><div class="ttname"><a href="group__connection.html#ga61e1f6386d18a568da50b998200eb87b">pn_connection_get_container</a></div><div class="ttdeci">const char * pn_connection_get_container(pn_connection_t *connection)</div><div class="ttdoc">Get the AMQP Container name advertised by a connection object. </div></div>
 <div class="ttc" id="group__connection_html_gabc8d505108a850837a0d2fb204875390"><div class="ttname"><a href="group__connection.html#gabc8d505108a850837a0d2fb204875390">pn_connection_offered_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_offered_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access/modify the AMQP offered capabilities data for a connection object. </div></div>
 <div class="ttc" id="group__connection_html_gad8b6c777b525c9da9401e3a770db15da"><div class="ttname"><a href="group__connection.html#gad8b6c777b525c9da9401e3a770db15da">pn_connection_attachments</a></div><div class="ttdeci">pn_record_t * pn_connection_attachments(pn_connection_t *connection)</div><div class="ttdoc">Get the attachments that are associated with a connection object. </div></div>
@@ -120,16 +120,16 @@ $(document).ready(function(){initNavTree('connection_8h_source.html','');});
 <div class="ttc" id="group__connection_html_ga8be7fdeb5a229d16e45fa122844fb285"><div class="ttname"><a href="group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285">pn_connection_set_password</a></div><div class="ttdeci">void pn_connection_set_password(pn_connection_t *connection, const char *password)</div><div class="ttdoc">Set the authentication password for a client connection. </div></div>
 <div class="ttc" id="group__connection_html_gac26de255ed04e73295d6aa973a663142"><div class="ttname"><a href="group__connection.html#gac26de255ed04e73295d6aa973a663142">pn_connection_properties</a></div><div class="ttdeci">pn_data_t * pn_connection_properties(pn_connection_t *connection)</div><div class="ttdoc">Access/modify the AMQP properties data for a connection object. </div></div>
 <div class="ttc" id="group__connection_html_ga7c88b4833cf81d801b27d00b45d137b5"><div class="ttname"><a href="group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5">pn_connection_release</a></div><div class="ttdeci">void pn_connection_release(pn_connection_t *connection)</div><div class="ttdoc">Release a connection object. </div></div>
-<div class="ttc" id="group__connection_html_ga9bf90f0f395d26e320293063b70d040f"><div class="ttname"><a href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_remote_offered_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access the AMQP offered capabilites supplied by the remote connection endpoint. </div></div>
+<div class="ttc" id="group__connection_html_ga9bf90f0f395d26e320293063b70d040f"><div class="ttname"><a href="group__connection.html#ga9bf90f0f395d26e320293063b70d040f">pn_connection_remote_offered_capabilities</a></div><div class="ttdeci">pn_data_t * pn_connection_remote_offered_capabilities(pn_connection_t *connection)</div><div class="ttdoc">Access the AMQP offered capabilities supplied by the remote connection endpoint. </div></div>
 <div class="ttc" id="group__connection_html_gac4a34e0b1fc5665b26ae47a80a422a1a"><div class="ttname"><a href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a></div><div class="ttdeci">void pn_connection_set_container(pn_connection_t *connection, const char *container)</div><div class="ttdoc">Set the AMQP Container name advertised by a connection object. </div></div>
 <div class="ttc" id="group__connection_html_ga2fd2089e8eaa2a362606498f233ada61"><div class="ttname"><a href="group__connection.html#ga2fd2089e8eaa2a362606498f233ada61">pn_connection_collect</a></div><div class="ttdeci">void pn_connection_collect(pn_connection_t *connection, pn_collector_t *collector)</div><div class="ttdoc">Associate a connection object with an event collector. </div></div>
 <div class="ttc" id="group__connection_html_ga4c0a2d40bb95202477ccc5aaa7456670"><div class="ttname"><a href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a></div><div class="ttdeci">void pn_connection_open(pn_connection_t *connection)</div><div class="ttdoc">Open a connection. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__connection_html_ga5f4b94211f97bbc3bb64642f6f597fe8"><div class="ttname"><a href="group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8">pn_connection_get_user</a></div><div class="ttdeci">const char * pn_connection_get_user(pn_connection_t *connection)</div><div class="ttdoc">Get the authentication username for a client connection. </div></div>
 <div class="ttc" id="group__connection_html_gabf25d7b763951b4a9c856536d6db0600"><div class="ttname"><a href="group__connection.html#gabf25d7b763951b4a9c856536d6db0600">pn_connection_remote_hostname</a></div><div class="ttdeci">const char * pn_connection_remote_hostname(pn_connection_t *connection)</div><div class="ttdoc">Get the AMQP Hostname set by the remote connection endpoint. </div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
-<div class="ttc" id="group__connection_html_gad3aad758ccb4690e78d40c1a73567d73"><div class="ttname"><a href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a></div><div class="ttdeci">pn_error_t * pn_connection_error(pn_connection_t *connection)</div></div>
-<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:269</div></div>
+<div class="ttc" id="group__connection_html_gad3aad758ccb4690e78d40c1a73567d73"><div class="ttname"><a href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a></div><div class="ttdeci">pn_error_t * pn_connection_error(pn_connection_t *connection)</div><div class="ttdoc">Deprecated </div></div>
+<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:267</div></div>
 <div class="ttc" id="group__connection_html_gaa9e59c468ec0568b1528f5f83c4b301d"><div class="ttname"><a href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a></div><div class="ttdeci">pn_connection_t * pn_connection(void)</div><div class="ttdoc">Factory to construct a new Connection. </div></div>
 <div class="ttc" id="group__connection_html_ga0c3bed8e6764915a137a9daff199ecbb"><div class="ttname"><a href="group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb">pn_connection_set_hostname</a></div><div class="ttdeci">void pn_connection_set_hostname(pn_connection_t *connection, const char *hostname)</div><div class="ttdoc">Set the name of the virtual host (either fully qualified or relative) to which this connection is con...</div></div>
 <div class="ttc" id="group__connection_html_gad8bd46661ca997b9b2c2c38cb6983c59"><div class="ttname"><a href="group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59">pn_connection_transport</a></div><div class="ttdeci">pn_transport_t * pn_connection_transport(pn_connection_t *connection)</div><div class="ttdoc">Get the transport bound to a connection object. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.html b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.html
index 8d6aa08..14bbcec 100755
--- a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.html
@@ -173,7 +173,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <tr class="separator:ga001b2f3c1bfe4d24d53b93d79dccbfe3"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="memItemLeft" align="right" valign="top">
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *c)</td></tr>
-<tr class="memdesc:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="mdescLeft">&#160;</td><td class="mdescRight">Close both sides side. <br /></td></tr>
+<tr class="memdesc:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="mdescLeft">&#160;</td><td class="mdescRight">Close both sides. <br /></td></tr>
 <tr class="separator:gad0c98415e0105efb71e8c1a8c4c1e5fb"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga00b32ae810a25ba6e172d6ed870982a5"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">pn_connection_driver_next_event</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *)</td></tr>
 <tr class="memdesc:ga00b32ae810a25ba6e172d6ed870982a5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the next event to handle.  <a href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">More...</a><br /></td></tr>
@@ -186,28 +186,31 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <tr class="memdesc:ga38f56836858b2d4a04ab961f650950d4"><td class="mdescLeft">&#160;</td><td class="mdescRight">Return true if the the driver is closed for reading and writing and there are no more events.  <a href="group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4">More...</a><br /></td></tr>
 <tr class="separator:ga38f56836858b2d4a04ab961f650950d4"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga373eb1f632468582d025f5d6acf9655e"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *name, const char *fmt,...)</td></tr>
-<tr class="memdesc:ga373eb1f632468582d025f5d6acf9655e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set IO error information.  <a href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">More...</a><br /></td></tr>
+<tr class="memdesc:ga373eb1f632468582d025f5d6acf9655e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set transport error.  <a href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">More...</a><br /></td></tr>
 <tr class="separator:ga373eb1f632468582d025f5d6acf9655e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gad774f90adceaf86748a0ae781f66daf2"><td class="memItemLeft" align="right" valign="top">
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *name, const char *fmt, va_list)</td></tr>
-<tr class="memdesc:gad774f90adceaf86748a0ae781f66daf2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set IO error information via a va_list, see <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set IO error information. ">pn_connection_driver_errorf()</a> <br /></td></tr>
+<tr class="memdesc:gad774f90adceaf86748a0ae781f66daf2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set transport error via a va_list, see <a class="el" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e" title="Set transport error. ">pn_connection_driver_errorf()</a> <br /></td></tr>
 <tr class="separator:gad774f90adceaf86748a0ae781f66daf2"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gada5c75a658ae2814f253a91723be9baf"><td class="memItemLeft" align="right" valign="top">
+<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a> (<a class="el" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch)</td></tr>
+<tr class="memdesc:gada5c75a658ae2814f253a91723be9baf"><td class="mdescLeft">&#160;</td><td class="mdescRight">If batch is part of a connection_driver, return the connection_driver address, else return NULL. <br /></td></tr>
+<tr class="separator:gada5c75a658ae2814f253a91723be9baf"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gadb682f03cb66b5898c4b285353e0005e"><td class="memItemLeft" align="right" valign="top">
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *msg)</td></tr>
-<tr class="memdesc:gadb682f03cb66b5898c4b285353e0005e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a string message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:gadb682f03cb66b5898c4b285353e0005e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gad603e8d72578bcedd2d9235f74f28f37" title="Log a message using a transport&#39;s logging mechanism. ">pn_transport_log()</a>. <br /></td></tr>
 <tr class="separator:gadb682f03cb66b5898c4b285353e0005e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga756d1d7130b79f639d71d331f9005cab"><td class="memItemLeft" align="right" valign="top">
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab">pn_connection_driver_logf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *fmt,...)</td></tr>
-<tr class="memdesc:ga756d1d7130b79f639d71d331f9005cab"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a printf formatted message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:ga756d1d7130b79f639d71d331f9005cab"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84" title="Log a printf formatted message using a transport&#39;s logging mechanism. ">pn_transport_logf()</a>. <br /></td></tr>
 <tr class="separator:ga756d1d7130b79f639d71d331f9005cab"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="memItemLeft" align="right" valign="top">
 void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a> (<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, const char *fmt, va_list ap)</td></tr>
-<tr class="memdesc:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="mdescLeft">&#160;</td><td class="mdescRight">Log a printf formatted message using the connection's transport log. <br /></td></tr>
+<tr class="memdesc:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f" title="Log a printf formatted message using a transport&#39;s logging mechanism. ">pn_transport_vlogf()</a>. <br /></td></tr>
 <tr class="separator:gabf97a6a0b608fd096fcaa4f2692c2c63"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gada5c75a658ae2814f253a91723be9baf"><td class="memItemLeft" align="right" valign="top">
-<a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a> (<a class="el" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch)</td></tr>
-<tr class="memdesc:gada5c75a658ae2814f253a91723be9baf"><td class="mdescLeft">&#160;</td><td class="mdescRight">If batch is part of a connection_driver, return the connection_driver address, else return NULL. <br /></td></tr>
-<tr class="separator:gada5c75a658ae2814f253a91723be9baf"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> **&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">pn_connection_driver_ptr</a> (<a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="memdesc:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Associate a pn_connection_t with its <a class="el" href="group__connection__driver.html#structpn__connection__driver__t" title="The elements needed to drive AMQP IO and events. ">pn_connection_driver_t</a>.  <a href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">More...</a><br /></td></tr>
+<tr class="separator:gab9d4f3255c83d7792fc17e5a020ff1c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p><b>Unsettled API</b> - An API for low-level IO integration. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.js b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.js
index e9f2e45..fe20c1e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h.js
@@ -21,8 +21,9 @@ var connection__driver_8h =
     [ "pn_connection_driver_finished", "group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4", null ],
     [ "pn_connection_driver_errorf", "group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e", null ],
     [ "pn_connection_driver_verrorf", "group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2", null ],
+    [ "pn_event_batch_connection_driver", "group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf", null ],
     [ "pn_connection_driver_log", "group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e", null ],
     [ "pn_connection_driver_logf", "group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab", null ],
     [ "pn_connection_driver_vlogf", "group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63", null ],
-    [ "pn_event_batch_connection_driver", "group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf", null ]
+    [ "pn_connection_driver_ptr", "group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0", null ]
 ];
\ 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


[39/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/listener_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/listener_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/listener_8h_source.html
index 968f3fe..3ac0efb 100755
--- a/content/releases/qpid-proton-master/proton/c/api/listener_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/listener_8h_source.html
@@ -93,17 +93,19 @@ $(document).ready(function(){initNavTree('listener_8h_source.html','');});
 <div class="title">listener.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="listener_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTENER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTENER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</spa
 n>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * spe
 cific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno"> 
   26</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;PNP_EXTERN <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *<a class="code" href="group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5">pn_listener</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00056"></a><span clas
 s="lineno">   56</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">pn_listener_free</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>*, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;PNP_EXTERN <a class="code" h
 ref="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> *pn_listener_get_context(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> pn_listener_set_context(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <span cla
 ss="keywordtype">void</span> *context);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNP_EXTERN pn_record_t *<a class="code" href="group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f">pn_listener_attachments</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104">pn_listener_close</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;</div><div class="line"><a name="l00110"></a><sp
 an class="lineno">  110</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__listener.html#ga994a35d101824296c6e6077f2a74ff61">pn_listener_proactor</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *c);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PNP_EXTERN <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *<a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<s
 pan class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;}</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* listener.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> types.h:422</div></div>
+<a href="listener_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTENER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTENER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</spa
 n>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * spe
 cific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno"> 
   26</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;PNP_EXTERN <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *<a class="code" href="group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5">pn_listener</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00056"></a><span clas
 s="lineno">   56</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">pn_listener_free</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">pn_listener_accept2</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00073"></a><span class="lineno"
 >   73</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">pn_listener_accept</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a>* listener, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;PNP_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00
 083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> *pn_listener_get_context(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> pn_listener_set_context(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;PNP_EXTERN pn_record_t *<a class="code" href="group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f">pn_listener_att
 achments</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener);</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104">pn_listener_close</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__listener.html#ga994a35d101824296c6e6077f2a74ff61">pn_listener_proactor</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf21
 6">pn_listener_t</a> *c);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PNP_EXTERN <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *<a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;}</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00129"></a><span class="lineno">
   129</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* listener.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> types.h:420</div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
-<div class="ttc" id="group__listener_html_gaaee3c3f3822484bc2e370406abf5b736"><div class="ttname"><a href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a></div><div class="ttdeci">PNP_EXTERN void pn_listener_accept(pn_listener_t *, pn_connection_t *)</div><div class="ttdoc">Bind connection to a new transport accepted from listener. </div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
+<div class="ttc" id="group__listener_html_ga3719a4ab17b8de42fc6bfb262018d070"><div class="ttname"><a href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">pn_listener_accept2</a></div><div class="ttdeci">PNP_EXTERN void pn_listener_accept2(pn_listener_t *listener, pn_connection_t *connection, pn_transport_t *transport)</div><div class="ttdoc">Accept an incoming connection request using transport and connection, which can be configured before ...</div></div>
 <div class="ttc" id="group__listener_html_ga994a35d101824296c6e6077f2a74ff61"><div class="ttname"><a href="group__listener.html#ga994a35d101824296c6e6077f2a74ff61">pn_listener_proactor</a></div><div class="ttdeci">PNP_EXTERN pn_proactor_t * pn_listener_proactor(pn_listener_t *c)</div><div class="ttdoc">The proactor associated with a listener. </div></div>
 <div class="ttc" id="group__listener_html_gae94f2acd3463fc0a42b1b5dd68d9326f"><div class="ttname"><a href="group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f">pn_listener_attachments</a></div><div class="ttdeci">PNP_EXTERN pn_record_t * pn_listener_attachments(pn_listener_t *listener)</div><div class="ttdoc">Get the attachments that are associated with a listener object. </div></div>
-<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:440</div></div>
+<div class="ttc" id="group__listener_html_ga8a100386ab4a079ae6924aeaafc72eb9"><div class="ttname"><a href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">pn_listener_accept</a></div><div class="ttdeci">PNP_EXTERN void pn_listener_accept(pn_listener_t *listener, pn_connection_t *connection)</div></div>
+<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:438</div></div>
 <div class="ttc" id="group__listener_html_gaa49d0d11a9f46a75fbbbebf6def2d4b2"><div class="ttname"><a href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a></div><div class="ttdeci">PNP_EXTERN pn_condition_t * pn_listener_condition(pn_listener_t *l)</div><div class="ttdoc">Get the error condition for a listener. </div></div>
 <div class="ttc" id="group__listener_html_gaf5769baf81fdfa80e5c4326dd4a9ab63"><div class="ttname"><a href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">pn_listener_free</a></div><div class="ttdeci">PNP_EXTERN void pn_listener_free(pn_listener_t *l)</div><div class="ttdoc">Free a listener. </div></div>
 <div class="ttc" id="group__listener_html_ga17a5b8573f00e16b233c59a3bb17c104"><div class="ttname"><a href="group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104">pn_listener_close</a></div><div class="ttdeci">PNP_EXTERN void pn_listener_close(pn_listener_t *l)</div><div class="ttdoc">Close the listener. </div></div>
 <div class="ttc" id="event_8h_html"><div class="ttname"><a href="event_8h.html">event.h</a></div><div class="ttdoc">Protocol and transport events. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__listener_html_gabba0a7d2e916188e3ec07d0acf8f3fc5"><div class="ttname"><a href="group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5">pn_listener</a></div><div class="ttdeci">PNP_EXTERN pn_listener_t * pn_listener(void)</div><div class="ttdoc">Create a listener to pass to pn_proactor_listen() </div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
 <div class="ttc" id="group__event_html_ga87f3028b4888632bbd56fb71ac737ae8"><div class="ttname"><a href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a></div><div class="ttdeci">struct pn_event_t pn_event_t</div><div class="ttdoc">Notification of a state change in the protocol engine. </div><div class="ttdef"><b>Definition:</b> event.h:75</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/log_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/log_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/log_8h_source.html
index 99526e6..0ed39b4 100755
--- a/content/releases/qpid-proton-master/proton/c/api/log_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/log_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/log.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -101,7 +101,7 @@ $(document).ready(function(){initNavTree('log_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>log.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/message_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/message_8h.html b/content/releases/qpid-proton-master/proton/c/api/message_8h.html
index f13ceaf..3657ecc 100755
--- a/content/releases/qpid-proton-master/proton/c/api/message_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/message_8h.html
@@ -265,17 +265,20 @@ Functions</h2></td></tr>
 <tr class="memdesc:gadadb16710eccb6d332d039acc9dc1042"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the annotations for a message.  <a href="group__message.html#gadadb16710eccb6d332d039acc9dc1042">More...</a><br /></td></tr>
 <tr class="separator:gadadb16710eccb6d332d039acc9dc1042"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">pn_message_properties</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg)</td></tr>
-<tr class="memdesc:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the properties for a message.  <a href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">More...</a><br /></td></tr>
+<tr class="memdesc:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get and set the properties for a message.  <a href="group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad">More...</a><br /></td></tr>
 <tr class="separator:ga43c7ee6ab70316145fb2bb5fcad210ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">pn_message_body</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg)</td></tr>
-<tr class="memdesc:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get/set the body of a message.  <a href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">More...</a><br /></td></tr>
+<tr class="memdesc:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get and set the body of a message.  <a href="group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1">More...</a><br /></td></tr>
 <tr class="separator:ga145c06edbcccfbe97136bfb5cb2b22b1"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab0bae90838f4661b0c82c15f25e1e988"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">pn_message_decode</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, const char *bytes, size_t size)</td></tr>
 <tr class="memdesc:gab0bae90838f4661b0c82c15f25e1e988"><td class="mdescLeft">&#160;</td><td class="mdescRight">Decode/load message content from AMQP formatted binary data.  <a href="group__message.html#gab0bae90838f4661b0c82c15f25e1e988">More...</a><br /></td></tr>
 <tr class="separator:gab0bae90838f4661b0c82c15f25e1e988"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">pn_message_encode</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, char *bytes, size_t *size)</td></tr>
-<tr class="memdesc:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode/save message content as AMQP formatted binary data.  <a href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">More...</a><br /></td></tr>
+<tr class="memdesc:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode a message as AMQP formatted binary data.  <a href="group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473">More...</a><br /></td></tr>
 <tr class="separator:ga2173bbce3c1f4b04074e42d2fe7da473"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">pn_message_send</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <a class="el" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> *buf)</td></tr>
+<tr class="memdesc:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Encode and send a message on a sender link.  <a href="group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5">More...</a><br /></td></tr>
+<tr class="separator:ga86cd32577f0e78bab29bd0e49869f0b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga013d429f94d653bc1e00f1f438a079a6"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__message.html#ga013d429f94d653bc1e00f1f438a079a6">pn_message_data</a> (<a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg, <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
 <tr class="memdesc:ga013d429f94d653bc1e00f1f438a079a6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Save message content into a pn_data_t object data.  <a href="group__message.html#ga013d429f94d653bc1e00f1f438a079a6">More...</a><br /></td></tr>
 <tr class="separator:ga013d429f94d653bc1e00f1f438a079a6"><td class="memSeparator" colspan="2">&#160;</td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/message_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/message_8h.js b/content/releases/qpid-proton-master/proton/c/api/message_8h.js
index d3894cc..7856b91 100755
--- a/content/releases/qpid-proton-master/proton/c/api/message_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/message_8h.js
@@ -53,5 +53,6 @@ var message_8h =
     [ "pn_message_body", "group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1", null ],
     [ "pn_message_decode", "group__message.html#gab0bae90838f4661b0c82c15f25e1e988", null ],
     [ "pn_message_encode", "group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473", null ],
+    [ "pn_message_send", "group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5", null ],
     [ "pn_message_data", "group__message.html#ga013d429f94d653bc1e00f1f438a079a6", null ]
 ];
\ 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


[47/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h_source.html
index ca1e72b..2d84885 100755
--- a/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/connection__driver_8h_source.html
@@ -93,38 +93,39 @@ $(document).ready(function(){initNavTree('connection__driver_8h_source.html','')
 <div class="title">connection_driver.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="connection__driver_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_DRIVER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_DRIVER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><sp
 an class="lineno">    7</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno
 ">   13</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;
 <span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00080
 "></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno"><a class="line" href="group__connection__driver.html">   90</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </s
 pan><a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> {</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;  <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;  <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;  <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;  <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> batch;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;} <a class="code" h
 ref="group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711">pn_connection_driver_t</a>;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__connection__driver.html#ga2330d329e295da740ef8d126657470c6">pn_connection_driver_init</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a>*, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>*, <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a>*);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__c
 onnection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56">pn_connection_driver_bind</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d);</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96">pn_connection_driver_destroy</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection__driver.html#ga96
 a6bf8efc2dd7b76734cb2432441333">pn_connection_driver_release_connection</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d);</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> <a class="code" href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438">pn_connection_driver_read_buffer</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gaa164510528ce160efddbde2245c43
 8b1">pn_connection_driver_read_done</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f">pn_connection_driver_read_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23">pn_connection_driver_read_closed</a>
 (<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160; PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> <a class="code" href="group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f">pn_connection_driver_write_buffer</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243">pn_connection_driver_write_done</a>(<a class="code" href="group__connecti
 on__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce">pn_connection_driver_write_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3">pn_connection_driver_write_closed</a>(<a class="code" href="group__connection__driver.html#structpn__connection_
 _driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> * c);</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;PN_EXTERN <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* <a class="code" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">pn_connection_driver_next_event</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver
 _t</a> *);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7">pn_connection_driver_has_event</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4">pn_connection_driver_finished</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00219"></a><span class="lineno">  219</spa
 n>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *name, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, 
 <span class="keyword">const</span> <span class="keywordtype">char</span> *name, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list);</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00239"></a><span class="lineno">  239</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *msg);</div><div class="line"><a name="l00240"></a><span class="lineno">  240</span>&#160;</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga756d1d7130b79f639d71d331f900
 5cab">pn_connection_driver_logf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list ap);</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;PN_EXTERN <a class="code" href="group__connectio
 n__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a>* <a class="code" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a>(<a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch);</div><div class="line"><a name="l00256"></a><span class="lineno">  256</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno"><a class="line" href="group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2">  261</a></span>&#160;<span class="preprocessor">#define PN_TRANSPORT_WRITE_CLOSED PN_TRANSPORT_HEAD_CLOSED</span></div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno"><a class="line" href="group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb">  267</a></span>&#160;<span class="preprocessor">#define PN_TRANSPORT_READ_CLOSED PN_TRANSPORT_TAI
 L_CLOSED</span></div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;}</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* connection_driver.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__connection__driver_html_gadb682f03cb66b5898c4b285353e0005e"><div class="ttname"><a href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a></div><div class="ttdeci">void pn_conn
 ection_driver_log(pn_connection_driver_t *d, const char *msg)</div><div class="ttdoc">Log a string message using the connection&amp;#39;s transport log. </div></div>
+<a href="connection__driver_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_DRIVER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_DRIVER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><sp
 an class="lineno">    7</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno
 ">   13</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;
 <span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00080
 "></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">#include &lt;stdarg.h&gt;</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno"><a class="line" href="group__connection__driver.html">   90</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </s
 pan><a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> {</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;  <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;  <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;  <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;  <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> batch;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;} <a class="code" h
 ref="group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711">pn_connection_driver_t</a>;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__connection__driver.html#ga2330d329e295da740ef8d126657470c6">pn_connection_driver_init</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a>*, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>*, <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a>*);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__c
 onnection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56">pn_connection_driver_bind</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d);</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96">pn_connection_driver_destroy</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *<a class="code" href="group__connection__driver.html#ga96
 a6bf8efc2dd7b76734cb2432441333">pn_connection_driver_release_connection</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d);</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> <a class="code" href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438">pn_connection_driver_read_buffer</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gaa164510528ce160efddbde2245c43
 8b1">pn_connection_driver_read_done</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f">pn_connection_driver_read_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23">pn_connection_driver_read_closed</a>
 (<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160; PN_EXTERN <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> <a class="code" href="group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f">pn_connection_driver_write_buffer</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243">pn_connection_driver_write_done</a>(<a class="code" href="group__connecti
 on__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce">pn_connection_driver_write_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3">pn_connection_driver_write_closed</a>(<a class="code" href="group__connection__driver.html#structpn__connection_
 _driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> * c);</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;PN_EXTERN <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* <a class="code" href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">pn_connection_driver_next_event</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver
 _t</a> *);</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7">pn_connection_driver_has_event</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00218"></a><span class="lineno">  218</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4">pn_connection_driver_finished</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *);</div><div class="line"><a name="l00219"></a><span class="lineno">  219</spa
 n>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *name, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, 
 <span class="keyword">const</span> <span class="keywordtype">char</span> *name, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, va_list);</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00240"></a><span class="lineno">  240</span>&#160;PN_EXTERN <a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a>* <a class="code" href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a>(<a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *batch);</div><div class="line"><a name="l00241"></a><span class="lineno">  241</span>&#160;</div><div class="line"><a name="l00246"></a><span class="lineno"><a class="line" href="group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2">  246</a></span>&#160;<span class="preprocessor">#define PN_TRANSPO
 RT_WRITE_CLOSED PN_TRANSPORT_HEAD_CLOSED</span></div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;</div><div class="line"><a name="l00252"></a><span class="lineno"><a class="line" href="group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb">  252</a></span>&#160;<span class="preprocessor">#define PN_TRANSPORT_READ_CLOSED PN_TRANSPORT_TAIL_CLOSED</span></div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *msg);</div><div class="line"><a name="l00258"></a><span class="lineno">  
 258</span>&#160;</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab">pn_connection_driver_logf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *fmt, ...);</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a>(<a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> *d, <span class="keyword">const</span> <span class="keywordtype">char</span> *fm
 t, va_list ap);</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00280"></a><span class="lineno">  280</span>&#160;PN_EXTERN <a class="code" href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a> **<a class="code" href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">pn_connection_driver_ptr</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00281"></a><span class="lineno">  281</span>&#160;</div><div class="line"><a name="l00286"></a><span class="lineno">  286</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;}</div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a n
 ame="l00289"></a><span class="lineno">  289</span>&#160;</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* connection_driver.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__connection__driver_html_gadb682f03cb66b5898c4b285353e0005e"><div class="ttname"><a href="group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e">pn_connection_driver_log</a></div><div class="ttdeci">void pn_connection_driver_log(pn_connection_driver_t *d, const char *msg)</div><div class="ttdoc">Deprecated - Use pn_transport_log(). </div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
 <div class="ttc" id="group__connection__driver_html_ga9793522a25c9741e8d17a570a47e9711"><div class="ttname"><a href="group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711">pn_connection_driver_t</a></div><div class="ttdeci">struct pn_connection_driver_t pn_connection_driver_t</div><div class="ttdoc">The elements needed to drive AMQP IO and events. </div></div>
 <div class="ttc" id="group__connection__driver_html_gad2bdef0f5abe7cf593afcee237c6af56"><div class="ttname"><a href="group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56">pn_connection_driver_bind</a></div><div class="ttdeci">int pn_connection_driver_bind(pn_connection_driver_t *d)</div><div class="ttdoc">Force binding of the transport. </div></div>
-<div class="ttc" id="group__connection__driver_html_ga373eb1f632468582d025f5d6acf9655e"><div class="ttname"><a href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a></div><div class="ttdeci">void pn_connection_driver_errorf(pn_connection_driver_t *d, const char *name, const char *fmt,...)</div><div class="ttdoc">Set IO error information. </div></div>
-<div class="ttc" id="group__connection__driver_html_gabf97a6a0b608fd096fcaa4f2692c2c63"><div class="ttname"><a href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a></div><div class="ttdeci">void pn_connection_driver_vlogf(pn_connection_driver_t *d, const char *fmt, va_list ap)</div><div class="ttdoc">Log a printf formatted message using the connection&amp;#39;s transport log. </div></div>
+<div class="ttc" id="group__connection__driver_html_ga373eb1f632468582d025f5d6acf9655e"><div class="ttname"><a href="group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e">pn_connection_driver_errorf</a></div><div class="ttdeci">void pn_connection_driver_errorf(pn_connection_driver_t *d, const char *name, const char *fmt,...)</div><div class="ttdoc">Set transport error. </div></div>
+<div class="ttc" id="group__connection__driver_html_gabf97a6a0b608fd096fcaa4f2692c2c63"><div class="ttname"><a href="group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63">pn_connection_driver_vlogf</a></div><div class="ttdeci">void pn_connection_driver_vlogf(pn_connection_driver_t *d, const char *fmt, va_list ap)</div><div class="ttdoc">Deprecated - Use pn_transport_vlogf(). </div></div>
 <div class="ttc" id="group__connection__driver_html_gada5c75a658ae2814f253a91723be9baf"><div class="ttname"><a href="group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf">pn_event_batch_connection_driver</a></div><div class="ttdeci">pn_connection_driver_t * pn_event_batch_connection_driver(pn_event_batch_t *batch)</div><div class="ttdoc">If batch is part of a connection_driver, return the connection_driver address, else return NULL...</div></div>
 <div class="ttc" id="group__connection__driver_html_ga00b32ae810a25ba6e172d6ed870982a5"><div class="ttname"><a href="group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5">pn_connection_driver_next_event</a></div><div class="ttdeci">pn_event_t * pn_connection_driver_next_event(pn_connection_driver_t *)</div><div class="ttdoc">Get the next event to handle. </div></div>
 <div class="ttc" id="group__connection__driver_html_gae51f2124706bb1674e2c623a2dc62da7"><div class="ttname"><a href="group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7">pn_connection_driver_has_event</a></div><div class="ttdeci">bool pn_connection_driver_has_event(pn_connection_driver_t *)</div><div class="ttdoc">True if pn_connection_driver_next_event() will return a non-NULL event. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__connection__driver_html_ga0dd152968de6ec06de352e1cbc51c438"><div class="ttname"><a href="group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438">pn_connection_driver_read_buffer</a></div><div class="ttdeci">pn_rwbytes_t pn_connection_driver_read_buffer(pn_connection_driver_t *)</div><div class="ttdoc">Get the read buffer. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__rwbytes__t"><div class="ttname"><a href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a></div><div class="ttdoc">A non-const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:233</div></div>
+<div class="ttc" id="group__api__types_html_structpn__rwbytes__t"><div class="ttname"><a href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a></div><div class="ttdoc">A non-const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:231</div></div>
 <div class="ttc" id="group__event_html_ga6bc581dfeaa8e8d46d07d37229d565c9"><div class="ttname"><a href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a></div><div class="ttdeci">struct pn_event_batch_t pn_event_batch_t</div><div class="ttdoc">Unsettled API - A batch of events that must be handled in sequence. </div><div class="ttdef"><b>Definition:</b> event.h:547</div></div>
 <div class="ttc" id="group__connection__driver_html_structpn__connection__driver__t"><div class="ttname"><a href="group__connection__driver.html#structpn__connection__driver__t">pn_connection_driver_t</a></div><div class="ttdoc">The elements needed to drive AMQP IO and events. </div><div class="ttdef"><b>Definition:</b> connection_driver.h:90</div></div>
-<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:415</div></div>
+<div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
 <div class="ttc" id="group__connection__driver_html_ga001b2f3c1bfe4d24d53b93d79dccbfe3"><div class="ttname"><a href="group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3">pn_connection_driver_write_closed</a></div><div class="ttdeci">bool pn_connection_driver_write_closed(pn_connection_driver_t *)</div><div class="ttdoc">True if write side is closed. </div></div>
 <div class="ttc" id="group__connection__driver_html_ga96a6bf8efc2dd7b76734cb2432441333"><div class="ttname"><a href="group__connection__driver.html#ga96a6bf8efc2dd7b76734cb2432441333">pn_connection_driver_release_connection</a></div><div class="ttdeci">pn_connection_t * pn_connection_driver_release_connection(pn_connection_driver_t *d)</div><div class="ttdoc">Disassociate the driver&amp;#39;s connection from its transport and collector and sets d-&gt;connection = NULL...</div></div>
 <div class="ttc" id="group__connection__driver_html_ga11b59aec2b54acdefd63dfbce8d09a3f"><div class="ttname"><a href="group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f">pn_connection_driver_read_close</a></div><div class="ttdeci">void pn_connection_driver_read_close(pn_connection_driver_t *)</div><div class="ttdoc">Close the read side. </div></div>
 <div class="ttc" id="group__connection__driver_html_ga56ccde529842f18774fdf827e86afa23"><div class="ttname"><a href="group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23">pn_connection_driver_read_closed</a></div><div class="ttdeci">bool pn_connection_driver_read_closed(pn_connection_driver_t *)</div><div class="ttdoc">True if read side is closed. </div></div>
 <div class="ttc" id="group__connection__driver_html_ga3e5795e14572eec632231fe9f916ca5f"><div class="ttname"><a href="group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f">pn_connection_driver_write_buffer</a></div><div class="ttdeci">pn_bytes_t pn_connection_driver_write_buffer(pn_connection_driver_t *)</div><div class="ttdoc">Get the write buffer. </div></div>
-<div class="ttc" id="group__connection__driver_html_gad774f90adceaf86748a0ae781f66daf2"><div class="ttname"><a href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a></div><div class="ttdeci">void pn_connection_driver_verrorf(pn_connection_driver_t *d, const char *name, const char *fmt, va_list)</div><div class="ttdoc">Set IO error information via a va_list, see pn_connection_driver_errorf() </div></div>
+<div class="ttc" id="group__connection__driver_html_gad774f90adceaf86748a0ae781f66daf2"><div class="ttname"><a href="group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2">pn_connection_driver_verrorf</a></div><div class="ttdeci">void pn_connection_driver_verrorf(pn_connection_driver_t *d, const char *name, const char *fmt, va_list)</div><div class="ttdoc">Set transport error via a va_list, see pn_connection_driver_errorf() </div></div>
 <div class="ttc" id="group__connection__driver_html_ga2330d329e295da740ef8d126657470c6"><div class="ttname"><a href="group__connection__driver.html#ga2330d329e295da740ef8d126657470c6">pn_connection_driver_init</a></div><div class="ttdeci">int pn_connection_driver_init(pn_connection_driver_t *, pn_connection_t *, pn_transport_t *)</div><div class="ttdoc">Set connection and transport to the provided values, or create a new pn_connection_t or pn_transport_...</div></div>
-<div class="ttc" id="group__connection__driver_html_gad0c98415e0105efb71e8c1a8c4c1e5fb"><div class="ttname"><a href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a></div><div class="ttdeci">void pn_connection_driver_close(pn_connection_driver_t *c)</div><div class="ttdoc">Close both sides side. </div></div>
+<div class="ttc" id="group__connection__driver_html_gab9d4f3255c83d7792fc17e5a020ff1c0"><div class="ttname"><a href="group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0">pn_connection_driver_ptr</a></div><div class="ttdeci">pn_connection_driver_t ** pn_connection_driver_ptr(pn_connection_t *connection)</div><div class="ttdoc">Associate a pn_connection_t with its pn_connection_driver_t. </div></div>
+<div class="ttc" id="group__connection__driver_html_gad0c98415e0105efb71e8c1a8c4c1e5fb"><div class="ttname"><a href="group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb">pn_connection_driver_close</a></div><div class="ttdeci">void pn_connection_driver_close(pn_connection_driver_t *c)</div><div class="ttdoc">Close both sides. </div></div>
 <div class="ttc" id="group__connection__driver_html_ga38f56836858b2d4a04ab961f650950d4"><div class="ttname"><a href="group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4">pn_connection_driver_finished</a></div><div class="ttdeci">bool pn_connection_driver_finished(pn_connection_driver_t *)</div><div class="ttdoc">Return true if the the driver is closed for reading and writing and there are no more events...</div></div>
 <div class="ttc" id="event_8h_html"><div class="ttname"><a href="event_8h.html">event.h</a></div><div class="ttdoc">Protocol and transport events. </div></div>
 <div class="ttc" id="group__connection__driver_html_gafdca1cd72d6da760d3df7981085b36ce"><div class="ttname"><a href="group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce">pn_connection_driver_write_close</a></div><div class="ttdeci">void pn_connection_driver_write_close(pn_connection_driver_t *)</div><div class="ttdoc">Close the write side. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__connection__driver_html_ga3e8959d7897cd9415f687981c1d94c96"><div class="ttname"><a href="group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96">pn_connection_driver_destroy</a></div><div class="ttdeci">void pn_connection_driver_destroy(pn_connection_driver_t *)</div><div class="ttdoc">Unbind, release and free the connection and transport. </div></div>
 <div class="ttc" id="group__connection__driver_html_gaead42b6a9356214d9e2bb591af009243"><div class="ttname"><a href="group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243">pn_connection_driver_write_done</a></div><div class="ttdeci">void pn_connection_driver_write_done(pn_connection_driver_t *, size_t n)</div><div class="ttdoc">Call when the first n bytes of pn_connection_driver_write_buffer() have been written to IO...</div></div>
-<div class="ttc" id="group__connection__driver_html_ga756d1d7130b79f639d71d331f9005cab"><div class="ttname"><a href="group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab">pn_connection_driver_logf</a></div><div class="ttdeci">void pn_connection_driver_logf(pn_connection_driver_t *d, const char *fmt,...)</div><div class="ttdoc">Log a printf formatted message using the connection&amp;#39;s transport log. </div></div>
+<div class="ttc" id="group__connection__driver_html_ga756d1d7130b79f639d71d331f9005cab"><div class="ttname"><a href="group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab">pn_connection_driver_logf</a></div><div class="ttdeci">void pn_connection_driver_logf(pn_connection_driver_t *d, const char *fmt,...)</div><div class="ttdoc">Deprecated - Use pn_transport_logf(). </div></div>
 <div class="ttc" id="group__connection__driver_html_gaa164510528ce160efddbde2245c438b1"><div class="ttname"><a href="group__connection__driver.html#gaa164510528ce160efddbde2245c438b1">pn_connection_driver_read_done</a></div><div class="ttdeci">void pn_connection_driver_read_done(pn_connection_driver_t *, size_t n)</div><div class="ttdoc">Process the first n bytes of data in pn_connection_driver_read_buffer() and reclaim the buffer space...</div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:214</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
 <div class="ttc" id="group__event_html_ga87f3028b4888632bbd56fb71ac737ae8"><div class="ttname"><a href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a></div><div class="ttdeci">struct pn_event_t pn_event_t</div><div class="ttdoc">Notification of a state change in the protocol engine. </div><div class="ttdef"><b>Definition:</b> event.h:75</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/delivery_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/delivery_8h.html b/content/releases/qpid-proton-master/proton/c/api/delivery_8h.html
index 88cb346..31c045c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/delivery_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/delivery_8h.html
@@ -122,8 +122,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga6a7ef2e317b4ed292cafbb358f0ba6ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a delivery on a link.  <a href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">More...</a><br /></td></tr>
 <tr class="separator:ga6a7ef2e317b4ed292cafbb358f0ba6ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga17c16f34252597f9e737efae1e2ebb81"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
+<tr class="memdesc:ga17c16f34252597f9e737efae1e2ebb81"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>.  <a href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">More...</a><br /></td></tr>
 <tr class="separator:ga17c16f34252597f9e737efae1e2ebb81"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga91519d3e4568ee8b622d3653e20f60a6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery, void *context)</td></tr>
+<tr class="memdesc:ga91519d3e4568ee8b622d3653e20f60a6"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331" title="Get the attachments that are associated with a delivery object. ">pn_delivery_attachments()</a>.  <a href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">More...</a><br /></td></tr>
 <tr class="separator:ga91519d3e4568ee8b622d3653e20f60a6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga3e014fc1759a212bc3ee9e513a274331"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga3e014fc1759a212bc3ee9e513a274331"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a delivery object.  <a href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">More...</a><br /></td></tr>
@@ -156,7 +158,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga23c7b3c678228ccb21378e7c8ec9a72d"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a delivery only has partial message data.  <a href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">More...</a><br /></td></tr>
 <tr class="separator:ga23c7b3c678228ccb21378e7c8ec9a72d"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga712690e0cc84419d7b7ca7c49a10b776"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
-<tr class="memdesc:ga712690e0cc84419d7b7ca7c49a10b776"><td class="mdescLeft">&#160;</td><td class="mdescRight">On the receiving side, check if the delivery has been aborted.  <a href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">More...</a><br /></td></tr>
+<tr class="memdesc:ga712690e0cc84419d7b7ca7c49a10b776"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a received delivery has been aborted.  <a href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">More...</a><br /></td></tr>
 <tr class="separator:ga712690e0cc84419d7b7ca7c49a10b776"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga533bd8dd766786695b6e71f8505252f1"><td class="memItemLeft" align="right" valign="top">bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">pn_delivery_writable</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga533bd8dd766786695b6e71f8505252f1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Check if a delivery is writable.  <a href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">More...</a><br /></td></tr>
@@ -177,7 +179,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga365b3efbdd225a239dcf4746127c5f33"><td class="mdescLeft">&#160;</td><td class="mdescRight">Return true if delivery is the current delivery for its link.  <a href="group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33">More...</a><br /></td></tr>
 <tr class="separator:ga365b3efbdd225a239dcf4746127c5f33"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga407e51ff91368568d15f938b1771357c"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
-<tr class="memdesc:ga407e51ff91368568d15f938b1771357c"><td class="mdescLeft">&#160;</td><td class="mdescRight">On the sending side, abort a delivery.  <a href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">More...</a><br /></td></tr>
+<tr class="memdesc:ga407e51ff91368568d15f938b1771357c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Abort a delivery being sent.  <a href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">More...</a><br /></td></tr>
 <tr class="separator:ga407e51ff91368568d15f938b1771357c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga98c275fd7158e8b9d7d48d70503d68df"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a> (<a class="el" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery)</td></tr>
 <tr class="memdesc:ga98c275fd7158e8b9d7d48d70503d68df"><td class="mdescLeft">&#160;</td><td class="mdescRight">Settle a delivery.  <a href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">More...</a><br /></td></tr>


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


[41/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/group__transport.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/group__transport.html b/content/releases/qpid-proton-master/proton/c/api/group__transport.html
index 9a65c22..29c7c44 100755
--- a/content/releases/qpid-proton-master/proton/c/api/group__transport.html
+++ b/content/releases/qpid-proton-master/proton/c/api/group__transport.html
@@ -165,7 +165,9 @@ Functions</h2></td></tr>
 <tr class="memitem:gac458d9fdb684f9501e89b96fc51f5c34"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gac458d9fdb684f9501e89b96fc51f5c34"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get additional information about the condition of the transport.  <a href="#gac458d9fdb684f9501e89b96fc51f5c34">More...</a><br /></td></tr>
 <tr class="separator:gac458d9fdb684f9501e89b96fc51f5c34"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memitem:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memItemLeft" align="right" valign="top"><a id="gaede0bc2a0038ccdc7e1b193e322147fa"></a>
+<a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga1a769e2e6c900c78c710407296cb4e13"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">pn_transport_bind</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:ga1a769e2e6c900c78c710407296cb4e13"><td class="mdescLeft">&#160;</td><td class="mdescRight">Binds the transport to an AMQP connection.  <a href="#ga1a769e2e6c900c78c710407296cb4e13">More...</a><br /></td></tr>
@@ -183,8 +185,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga30d129d04a387ea34515c1641b83521b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the tracing function used by a transport.  <a href="#ga30d129d04a387ea34515c1641b83521b">More...</a><br /></td></tr>
 <tr class="separator:ga30d129d04a387ea34515c1641b83521b"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga000b2b9ab82139defb1a103f220ec58e"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:ga000b2b9ab82139defb1a103f220ec58e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>.  <a href="#ga000b2b9ab82139defb1a103f220ec58e">More...</a><br /></td></tr>
 <tr class="separator:ga000b2b9ab82139defb1a103f220ec58e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac22041ff85d1a1f5287ac2ba826edb74"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, void *context)</td></tr>
+<tr class="memdesc:gac22041ff85d1a1f5287ac2ba826edb74"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>.  <a href="#gac22041ff85d1a1f5287ac2ba826edb74">More...</a><br /></td></tr>
 <tr class="separator:gac22041ff85d1a1f5287ac2ba826edb74"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gabdd6d56837a028097b1676350d65a864"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864">pn_transport_attachments</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gabdd6d56837a028097b1676350d65a864"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a transport object.  <a href="#gabdd6d56837a028097b1676350d65a864">More...</a><br /></td></tr>
@@ -225,9 +229,13 @@ Functions</h2></td></tr>
 <tr class="memitem:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5">pn_transport_get_remote_idle_timeout</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the idle timeout for a transport's remote peer.  <a href="#gabdcbd5d08c5b5cd3603dee74421985b5">More...</a><br /></td></tr>
 <tr class="separator:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *bytes, size_t available)</td></tr>
+<tr class="memitem:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memItemLeft" align="right" valign="top"><a id="ga93f5efd9d63ebd1b1498fdace388ec3d"></a>
+ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *bytes, size_t available)</td></tr>
+<tr class="memdesc:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, char *bytes, size_t size)</td></tr>
+<tr class="memitem:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memItemLeft" align="right" valign="top"><a id="gae72fdee3b8aae3cb484b0ed98c2b802e"></a>
+ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, char *bytes, size_t size)</td></tr>
+<tr class="memdesc:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaa079bb5f5b9ea10734c9d8af26fba333"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">pn_transport_capacity</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gaa079bb5f5b9ea10734c9d8af26fba333"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the amount of free space for input following the transport's tail pointer.  <a href="#gaa079bb5f5b9ea10734c9d8af26fba333">More...</a><br /></td></tr>
@@ -558,7 +566,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 <p>Set whether a non encrypted transport connection is allowed. </p>
 <p>There are several ways within the AMQP protocol suite to get encrypted connections:</p><ul>
 <li>Use TLS</li>
-<li>Use a SASL with a mechanism that supports saecurity layers</li>
+<li>Use a SASL with a mechanism that supports security layers</li>
 </ul>
 <p>The default if this option is not set is to allow unencrypted connections.</p>
 <dl class="params"><dt>Parameters</dt><dd>
@@ -616,7 +624,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Get additional information about the condition of the transport. </p>
-<p>When a PN_TRANSPORT_ERROR event occurs, this operation can be used to access the details of the error condtion.</p>
+<p>When a PN_TRANSPORT_ERROR event occurs, this operation can be used to access the details of the error condition.</p>
 <p>The pointer returned by this operation is valid until the transport object is freed.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
@@ -628,24 +636,6 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 
 </div>
 </div>
-<a id="gaede0bc2a0038ccdc7e1b193e322147fa"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#gaede0bc2a0038ccdc7e1b193e322147fa">&#9670;&nbsp;</a></span>pn_transport_error()</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a>* pn_transport_error </td>
-          <td>(</td>
-          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
-          <td class="paramname"><em>transport</em></td><td>)</td>
-          <td></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-</div>
-</div>
 <a id="ga1a769e2e6c900c78c710407296cb4e13"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#ga1a769e2e6c900c78c710407296cb4e13">&#9670;&nbsp;</a></span>pn_transport_bind()</h2>
 
@@ -816,8 +806,10 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>. </p>
 <p>Get the application context that is associated with a transport object.</p>
-<p>The application context for a transport may be set using <a class="el" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a>.</p>
+<p>The application context for a transport may be set using <a class="el" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74" title="Deprecated - Use pn_transport_attachments(). ">pn_transport_set_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport whose context is to be returned. </td></tr>
@@ -853,8 +845,10 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
         </tr>
       </table>
 </div><div class="memdoc">
+
+<p><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>. </p>
 <p>Set a new application context for a transport object.</p>
-<p>The application context for a transport object may be retrieved using <a class="el" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a>.</p>
+<p>The application context for a transport object may be retrieved using <a class="el" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e" title="Deprecated - Use pn_transport_attachments(). ">pn_transport_get_context</a>.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport object </td></tr>
@@ -1078,7 +1072,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Set the maximum allowed channel number for a transport. </p>
-<p>Note that this is the maximum channel number allowed, giving a valid channel number range of [0..channel_max]. Therefore the maximum number of simultaineously active channels will be channel_max plus 1. You can call this function more than once to raise and lower the limit your application imposes on max channels for this transport. However, smaller limits may be imposed by this library, or by the remote peer. After the OPEN frame has been sent to the remote peer, further calls to this function will have no effect.</p>
+<p>Note that this is the maximum channel number allowed, giving a valid channel number range of [0..channel_max]. Therefore the maximum number of simultaneously active channels will be channel_max plus 1. You can call this function more than once to raise and lower the limit your application imposes on max channels for this transport. However, smaller limits may be imposed by this library, or by the remote peer. After the OPEN frame has been sent to the remote peer, further calls to this function will have no effect.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>a transport object </td></tr>
@@ -1302,74 +1296,6 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 
 </div>
 </div>
-<a id="ga93f5efd9d63ebd1b1498fdace388ec3d"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ga93f5efd9d63ebd1b1498fdace388ec3d">&#9670;&nbsp;</a></span>pn_transport_input()</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname">ssize_t pn_transport_input </td>
-          <td>(</td>
-          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
-          <td class="paramname"><em>transport</em>, </td>
-        </tr>
-        <tr>
-          <td class="paramkey"></td>
-          <td></td>
-          <td class="paramtype">const char *&#160;</td>
-          <td class="paramname"><em>bytes</em>, </td>
-        </tr>
-        <tr>
-          <td class="paramkey"></td>
-          <td></td>
-          <td class="paramtype">size_t&#160;</td>
-          <td class="paramname"><em>available</em>&#160;</td>
-        </tr>
-        <tr>
-          <td></td>
-          <td>)</td>
-          <td></td><td></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-</div>
-</div>
-<a id="gae72fdee3b8aae3cb484b0ed98c2b802e"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#gae72fdee3b8aae3cb484b0ed98c2b802e">&#9670;&nbsp;</a></span>pn_transport_output()</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname">ssize_t pn_transport_output </td>
-          <td>(</td>
-          <td class="paramtype"><a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *&#160;</td>
-          <td class="paramname"><em>transport</em>, </td>
-        </tr>
-        <tr>
-          <td class="paramkey"></td>
-          <td></td>
-          <td class="paramtype">char *&#160;</td>
-          <td class="paramname"><em>bytes</em>, </td>
-        </tr>
-        <tr>
-          <td class="paramkey"></td>
-          <td></td>
-          <td class="paramtype">size_t&#160;</td>
-          <td class="paramname"><em>size</em>&#160;</td>
-        </tr>
-        <tr>
-          <td></td>
-          <td>)</td>
-          <td></td><td></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-</div>
-</div>
 <a id="gaa079bb5f5b9ea10734c9d8af26fba333"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#gaa079bb5f5b9ea10734c9d8af26fba333">&#9670;&nbsp;</a></span>pn_transport_capacity()</h2>
 
@@ -1387,7 +1313,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Get the amount of free space for input following the transport's tail pointer. </p>
-<p>If the engine is in an exceptional state such as encountering an error condition or reaching the end of stream state, a negative value will be returned indicating the condition. If an error is indicated, futher details can be obtained from <a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a>. Calls to <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> may alter the value of this pointer. See <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> for details.</p>
+<p>If the engine is in an exceptional state such as encountering an error condition or reaching the end of stream state, a negative value will be returned indicating the condition. If an error is indicated, further details can be obtained from <a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa" title="Deprecated ">pn_transport_error</a>. Calls to <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> may alter the value of this pointer. See <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> for details.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport </td></tr>
@@ -1415,7 +1341,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Get the transport's tail pointer. </p>
-<p>The amount of free space following this pointer is reported by <a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333" title="Get the amount of free space for input following the transport&#39;s tail pointer. ">pn_transport_capacity</a>. Calls to <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> may alther the value of this pointer. See <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> for details.</p>
+<p>The amount of free space following this pointer is reported by <a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333" title="Get the amount of free space for input following the transport&#39;s tail pointer. ">pn_transport_capacity</a>. Calls to <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> may alter the value of this pointer. See <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> for details.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport </td></tr>
@@ -1459,7 +1385,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Pushes the supplied bytes into the tail of the transport. </p>
-<p>This is equivalent to copying <code>size</code> bytes afther the tail pointer and then calling <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> with an argument of <code>size</code>. Only some of the bytes will be copied if there is insufficienty capacity available. Use <a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333" title="Get the amount of free space for input following the transport&#39;s tail pointer. ">pn_transport_capacity</a> to determine how much capacity the transport has.</p>
+<p>This is equivalent to copying <code>size</code> bytes after the tail pointer and then calling <a class="el" href="group__transport.html#ga1f52a6f11322873e74b9daf004269a91" title="Process input data following the tail pointer. ">pn_transport_process</a> with an argument of <code>size</code>. Only some of the bytes will be copied if there is insufficient capacity available. Use <a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333" title="Get the amount of free space for input following the transport&#39;s tail pointer. ">pn_transport_capacity</a> to determine how much capacity the transport has.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport </td></tr>
@@ -1556,7 +1482,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Get the number of pending output bytes following the transport's head pointer. </p>
-<p>If the engine is in an exceptional state such as encountering an error condition or reaching the end of stream state, a negative value will be returned indicating the condition. If an error is indicated, further details can be obtained from <a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a>. Calls to <a class="el" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9" title="Removes size bytes of output from the pending output queue following the transport&#39;s head pointer...">pn_transport_pop</a> may alter the value of this pointer. See <a class="el" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9" title="Removes size bytes of output from the pending output queue following the transport&#39;s head pointer...">pn_transport_pop</a> for details.</p>
+<p>If the engine is in an exceptional state such as encountering an error condition or reaching the end of stream state, a negative value will be returned indicating the condition. If an error is indicated, further details can be obtained from <a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa" title="Deprecated ">pn_transport_error</a>. Calls to <a class="el" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9" title="Removes size bytes of output from the pending output queue following the transport&#39;s head pointer...">pn_transport_pop</a> may alter the value of this pointer. See <a class="el" href="group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9" title="Removes size bytes of output from the pending output queue following the transport&#39;s head pointer...">pn_transport_pop</a> for details.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport </td></tr>
@@ -1761,7 +1687,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="grou
 </div><div class="memdoc">
 
 <p>Process any pending transport timer events. </p>
-<p>This method should be called after all pending input has been processed by the transport (see <a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a>), and before generating output (see <a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a>). It returns the deadline for the next pending timer event, if any are present.</p>
+<p>This method should be called after all pending input has been processed by the transport (see <a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d" title="Deprecated ">pn_transport_input</a>), and before generating output (see <a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e" title="Deprecated ">pn_transport_output</a>). It returns the deadline for the next pending timer event, if any are present.</p>
 <dl class="params"><dt>Parameters</dt><dd>
   <table class="params">
     <tr><td class="paramdir">[in]</td><td class="paramname">transport</td><td>the transport to process. </td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/handlers_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/handlers_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/handlers_8h_source.html
index 6010a77..91badb8 100755
--- a/content/releases/qpid-proton-master/proton/c/api/handlers_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/handlers_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/handlers.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -101,7 +101,7 @@ $(document).ready(function(){initNavTree('handlers_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>handlers.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/import__export_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/import__export_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/import__export_8h_source.html
index b5d77f1..b5100b8 100755
--- a/content/releases/qpid-proton-master/proton/c/api/import__export_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/import__export_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/import_export.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('import__export_8h_source.html','');});
 <div class="title">import_export.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_IMPORT_EXPORT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_IMPORT_EXPORT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="l
 ine"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l0
 0014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span clas
 s="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="comment">// Compiler specific mechanisms for managing the import and export of</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="comment">// symbols between shared obj
 ects.</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="comment">// PN_EXPORT         - Export declaration</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">// PN_IMPORT         - Import declaration</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#if defined(WIN32) &amp;&amp; !defined(PROTON_DECLARE_STATIC)</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00039"></a><span class="lineno"> 
   39</span>&#160;  <span class="comment">// Import and Export definitions for Windows:</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#  define PN_EXPORT __declspec(dllexport)</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#  define PN_IMPORT __declspec(dllimport)</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;  <span class="comment">// Non-Windows (Linux, etc.) definitions:</span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</
 span>&#160;  <span class="comment">//</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="preprocessor">#  define PN_EXPORT __attribute ((visibility (&quot;default&quot;)))</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#  define PN_IMPORT</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="comment">// For core proton library symbols</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="preprocessor">#if defined(qpid_proton_core_EXPORTS) || defined(qpid_proton_EXPORTS)</span></di
 v><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="preprocessor">#  define PN_EXTERN PN_EXPORT</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#  define PN_EXTERN PN_IMPORT</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="comment">// For extra proton symbols</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#if defined(qpid_proton_EXPORTS)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<s
 pan class="preprocessor">#  define PNX_EXTERN PN_EXPORT</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor">#  define PNX_EXTERN PN_IMPORT</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* import_export.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents -->
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_IMPORT_EXPORT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_IMPORT_EXPORT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="l
 ine"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l0
 0014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span clas
 s="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="comment">  Compiler specific mechanisms for managing the import and export of</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="comment">  symbols between shared objec
 ts. </span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="comment">  PN_EXPORT         - Export declaration </span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="comment">  PN_IMPORT         - Import declaration</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">*/</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#if defined(WIN32) &amp;&amp; !defined(PROTON_DECLARE_STATIC)</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="comment">/* Import and Export definitions for Windows: */</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="preprocessor">#  define PN_EXPORT __declspe
 c(dllexport)</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#  define PN_IMPORT __declspec(dllimport)</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="comment">/* Non-Windows (Linux, etc.) definitions */</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#  define PN_EXPORT __attribute ((visibility (&quot;default&quot;)))</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="preprocessor">#  define PN_IMPORT</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;</div><di
 v class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="comment">/* For core proton library symbols */</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#if defined(qpid_proton_core_EXPORTS) || defined(qpid_proton_EXPORTS)</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#  define PN_EXTERN PN_EXPORT</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="preprocessor">#  define PN_EXTERN PN_IMPORT</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00053"></a
 ><span class="lineno">   53</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="comment">/* For proactor proton symbols */</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="preprocessor">#if defined(qpid_proton_proactor_EXPORTS) || defined(qpid_proton_EXPORTS)</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#  define PNP_EXTERN PN_EXPORT</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#  define PNP_EXTERN PN_IMPORT</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span
 >&#160;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="comment">/* For extra proton symbols */</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#if defined(qpid_proton_EXPORTS)</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor">#  define PNX_EXTERN PN_EXPORT</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#  define PNX_EXTERN PN_IMPORT</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   6
 8</span>&#160;<span class="preprocessor">#if ! defined(PN_USE_DEPRECATED_API)</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#  if defined(WIN32)</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="preprocessor">#    define PN_DEPRECATED(message) __declspec(deprecated(message))</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="preprocessor">#  elif defined __GNUC__</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#    if (__GNUC__ * 10000 + __GNUC_MINOR__ * 100 + __GNUC_PATCHLEVEL__) &lt; 40500</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="preprocessor">#      define PN_DEPRECATED(message) __attribute__((deprecated))</span></div><div class="line"><a name="l00074"></a><span class="lineno"> 
   74</span>&#160;<span class="preprocessor">#    else</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#      define PN_DEPRECATED(message) __attribute__((deprecated(message)))</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#    endif</span></div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#ifndef PN_DEPRECATED</span></div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">#  define  PN_DEPRECATED(message)</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>
 &#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* import_export.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
@@ -101,7 +101,7 @@ $(document).ready(function(){initNavTree('import__export_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>import_export.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/link_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/link_8h.html b/content/releases/qpid-proton-master/proton/c/api/link_8h.html
index 7bd691f..fd53852 100755
--- a/content/releases/qpid-proton-master/proton/c/api/link_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/link_8h.html
@@ -135,8 +135,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:gadd3b8899fe023d3506fb88d228d6b1b7"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a link object.  <a href="group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7">More...</a><br /></td></tr>
 <tr class="separator:gadd3b8899fe023d3506fb88d228d6b1b7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga93e6b527743f433da2ff367c1b2c500a"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
+<tr class="memdesc:ga93e6b527743f433da2ff367c1b2c500a"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>.  <a href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">More...</a><br /></td></tr>
 <tr class="separator:ga93e6b527743f433da2ff367c1b2c500a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga376f2cc18bbd771d95aa8222586d19b2"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, void *context)</td></tr>
+<tr class="memdesc:ga376f2cc18bbd771d95aa8222586d19b2"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69" title="Get the attachments that are associated with a link object. ">pn_link_attachments()</a>.  <a href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">More...</a><br /></td></tr>
 <tr class="separator:ga376f2cc18bbd771d95aa8222586d19b2"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga8b19ffdb7934940fa7c5fd75c5fe2d69"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">pn_link_attachments</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
 <tr class="memdesc:ga8b19ffdb7934940fa7c5fd75c5fe2d69"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a link object.  <a href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">More...</a><br /></td></tr>
@@ -154,6 +156,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:gad502b38bc184ad0bfaa86dede81f62c9"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the endpoint state flags for a link.  <a href="group__link.html#gad502b38bc184ad0bfaa86dede81f62c9">More...</a><br /></td></tr>
 <tr class="separator:gad502b38bc184ad0bfaa86dede81f62c9"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
+<tr class="memdesc:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b>  <a href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">More...</a><br /></td></tr>
 <tr class="separator:gaf6f11d778aa4622d8aa5db8962bb1f0a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga52c99044eabb7712efa2f1098c760804"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__link.html#ga52c99044eabb7712efa2f1098c760804">pn_link_condition</a> (<a class="el" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link)</td></tr>
 <tr class="memdesc:ga52c99044eabb7712efa2f1098c760804"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local condition associated with a link endpoint.  <a href="group__link.html#ga52c99044eabb7712efa2f1098c760804">More...</a><br /></td></tr>


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


[32/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex6.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex6.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex6.js
index 032de24..4a32446 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex6.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex6.js
@@ -1,142 +1,184 @@
 var NAVTREEINDEX6 =
 {
-"group__transport.html#ga4695788da8491f0c7104bfe36634ff94":[4,0,0,18,5],
-"group__transport.html#ga4695788da8491f0c7104bfe36634ff94":[2,0,8,5],
-"group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85":[4,0,0,18,40],
-"group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85":[2,0,8,41],
-"group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b":[2,0,8,42],
-"group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b":[4,0,0,18,41],
-"group__transport.html#ga51573625b6940884fed214b615f42e0f":[2,0,8,33],
-"group__transport.html#ga51573625b6940884fed214b615f42e0f":[4,0,0,18,32],
-"group__transport.html#ga55c589d9b3e69057b130036c3c2173df":[2,0,8,53],
-"group__transport.html#ga55c589d9b3e69057b130036c3c2173df":[4,0,0,18,52],
-"group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694":[2,0,8,52],
-"group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694":[4,0,0,18,51],
-"group__transport.html#ga6980396c3d890b86656167c3a063eee7":[4,0,0,18,34],
-"group__transport.html#ga6980396c3d890b86656167c3a063eee7":[2,0,8,35],
-"group__transport.html#ga6ab28051242631d9bea4814e8670ab90":[4,0,0,18,9],
-"group__transport.html#ga6ab28051242631d9bea4814e8670ab90":[2,0,8,10],
-"group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58":[2,0,8,11],
-"group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58":[4,0,0,18,10],
-"group__transport.html#ga7065ad65f95c995a24e416edc95aead4":[2,0,8,3],
-"group__transport.html#ga7065ad65f95c995a24e416edc95aead4":[4,0,0,18,3],
-"group__transport.html#ga737021ca419e948932071aad2ad38c5b":[2,0,8,15],
-"group__transport.html#ga737021ca419e948932071aad2ad38c5b":[4,0,0,18,14],
-"group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7":[2,0,8,21],
-"group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7":[4,0,0,18,20],
-"group__transport.html#ga81adf1fd6fa28054f2f80c424aa98122":[2,0,8,45],
-"group__transport.html#ga81adf1fd6fa28054f2f80c424aa98122":[4,0,0,18,44],
-"group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d":[2,0,8,13],
-"group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d":[4,0,0,18,12],
-"group__transport.html#ga8f080d7fb1e7fea2c93391d0b8f59773":[2,0,8,30],
-"group__transport.html#ga8f080d7fb1e7fea2c93391d0b8f59773":[4,0,0,18,29],
-"group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61":[2,0,8,56],
-"group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61":[4,0,0,18,55],
-"group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d":[2,0,8,38],
-"group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d":[4,0,0,18,37],
-"group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333":[2,0,8,40],
-"group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333":[4,0,0,18,39],
-"group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289":[4,0,0,18,43],
-"group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289":[2,0,8,44],
-"group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56":[2,0,8,20],
-"group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56":[4,0,0,18,19],
-"group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072":[4,0,0,18,48],
-"group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072":[2,0,8,49],
-"group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef":[4,0,0,18,49],
-"group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef":[2,0,8,50],
-"group__transport.html#gab8e04b4c128379ff27e6b801c0bce494":[2,0,8,2],
-"group__transport.html#gab8e04b4c128379ff27e6b801c0bce494":[4,0,0,18,2],
-"group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5":[2,0,8,37],
-"group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5":[4,0,0,18,36],
-"group__transport.html#gabdd6d56837a028097b1676350d65a864":[2,0,8,25],
-"group__transport.html#gabdd6d56837a028097b1676350d65a864":[4,0,0,18,24],
-"group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052":[2,0,8,29],
-"group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052":[4,0,0,18,28],
-"group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74":[2,0,8,24],
-"group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74":[4,0,0,18,23],
-"group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8":[2,0,8,7],
-"group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8":[4,0,0,19,17],
-"group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34":[4,0,0,18,15],
-"group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34":[2,0,8,16],
-"group__transport.html#gac5bebd26c0942bc17d7fad36577110f8":[2,0,8,9],
-"group__transport.html#gac5bebd26c0942bc17d7fad36577110f8":[4,0,0,18,8],
-"group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f":[4,0,0,18,26],
-"group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f":[2,0,8,27],
-"group__transport.html#gad603e8d72578bcedd2d9235f74f28f37":[2,0,8,26],
-"group__transport.html#gad603e8d72578bcedd2d9235f74f28f37":[4,0,0,18,25],
-"group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e":[2,0,8,39],
-"group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e":[4,0,0,18,38],
-"group__transport.html#gae8f32e46e94953bab10bee530eee9044":[4,0,0,18,0],
-"group__transport.html#gae8f32e46e94953bab10bee530eee9044":[2,0,8,0],
-"group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3":[2,0,8,6],
-"group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3":[4,0,0,18,6],
-"group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34":[4,0,0,18,13],
-"group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34":[2,0,8,14],
-"group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa":[4,0,0,18,16],
-"group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa":[2,0,8,17],
-"group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77":[4,0,0,18,7],
-"group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77":[2,0,8,8],
-"group__transport.html#gafb1c98602d17524eb40e48bf610362d7":[4,0,0,18,35],
-"group__transport.html#gafb1c98602d17524eb40e48bf610362d7":[2,0,8,36],
-"group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8":[2,0,8,1],
-"group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8":[4,0,0,18,1],
-"group__transport.html#gaff7c08aeb92596ad9d269468d1557647":[2,0,8,31],
-"group__transport.html#gaff7c08aeb92596ad9d269468d1557647":[4,0,0,18,30],
-"group__types.html":[2,1],
-"group__url.html":[2,5],
-"group__url.html#ga04bdbeb6e80fe9c284bd53869106376e":[4,0,0,20,8],
-"group__url.html#ga1a084548853885c874b1d0d435ef947c":[4,0,0,20,16],
-"group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b":[2,5,4],
-"group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b":[4,0,0,20,4],
-"group__url.html#ga389ea60e7d9bb206d60e383eaa8df3b4":[4,0,0,20,9],
-"group__url.html#ga3b9cbf8a77179b15b2100870913d6aaf":[4,0,0,20,14],
-"group__url.html#ga52876d19683cc9fb3318e29b297a0dfa":[4,0,0,20,15],
-"group__url.html#ga53ec7ab65dddea7383e64c6b2c58104e":[4,0,0,20,7],
-"group__url.html#ga5eb2682f856fa187bc99f0f46774aeb8":[4,0,0,20,12],
-"group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d":[4,0,0,20,5],
-"group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d":[2,5,5],
-"group__url.html#ga8b19840fe7ff1166c6583a7445eed325":[2,5,1],
-"group__url.html#ga8b19840fe7ff1166c6583a7445eed325":[4,0,0,20,1],
-"group__url.html#ga9162f3f1ba4bc374f079f9c01c3dee99":[4,0,0,20,6],
-"group__url.html#ga9939dda9f21f76d336ea7618fb6c4f2c":[4,0,0,20,10],
-"group__url.html#gaaa9f2f29b90525fbf73739cae8b84776":[2,5,2],
-"group__url.html#gaaa9f2f29b90525fbf73739cae8b84776":[4,0,0,20,2],
-"group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1":[2,5,3],
-"group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1":[4,0,0,20,3],
-"group__url.html#gabaa60d37795438556e4db952a50e35a7":[4,0,0,20,11],
-"group__url.html#gac72ebae7180d58003d489f2e4005d0c1":[4,0,0,20,17],
-"group__url.html#gafbe4340c29b1abd7394767456ad3b8ea":[4,0,0,20,0],
-"group__url.html#gafbe4340c29b1abd7394767456ad3b8ea":[2,5,0],
-"group__url.html#gafefe82e512fbdede2f1f539cf07b8bff":[4,0,0,20,13],
-"index.html":[0],
+"group__transport.html#ga09a0d15514ca9a14eb40f12425a52797":[3,0,8,47],
+"group__transport.html#ga09a0d15514ca9a14eb40f12425a52797":[5,0,0,27,46],
+"group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9":[5,0,0,27,53],
+"group__transport.html#ga0f2abc6827e9370c0aebb2e5dd7535a9":[3,0,8,54],
+"group__transport.html#ga1a769e2e6c900c78c710407296cb4e13":[3,0,8,18],
+"group__transport.html#ga1a769e2e6c900c78c710407296cb4e13":[5,0,0,27,17],
+"group__transport.html#ga1f52a6f11322873e74b9daf004269a91":[3,0,8,43],
+"group__transport.html#ga1f52a6f11322873e74b9daf004269a91":[5,0,0,27,42],
+"group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84":[3,0,8,28],
+"group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84":[5,0,0,27,27],
+"group__transport.html#ga285b4cced59c665ae178adf26128d3fc":[5,0,0,27,11],
+"group__transport.html#ga285b4cced59c665ae178adf26128d3fc":[3,0,8,12],
+"group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50":[3,0,8,19],
+"group__transport.html#ga2a66ff267333651eb166f3f6fa4ede50":[5,0,0,27,18],
+"group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf":[3,0,8,57],
+"group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf":[5,0,0,27,56],
+"group__transport.html#ga30d129d04a387ea34515c1641b83521b":[5,0,0,27,21],
+"group__transport.html#ga30d129d04a387ea34515c1641b83521b":[3,0,8,22],
+"group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9":[3,0,8,48],
+"group__transport.html#ga31470f0b0dbfd2c8c2929cc170858dc9":[5,0,0,27,47],
+"group__transport.html#ga351823e18e043576078f361d7dfe1cce":[5,0,0,27,33],
+"group__transport.html#ga351823e18e043576078f361d7dfe1cce":[3,0,8,34],
+"group__transport.html#ga3887e8d8c60d06df9978947edaf4d461":[5,0,0,27,54],
+"group__transport.html#ga3887e8d8c60d06df9978947edaf4d461":[3,0,8,55],
+"group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688":[5,0,0,27,4],
+"group__transport.html#ga3bde88d15fcfda400a36d8f9e5d51688":[3,0,8,4],
+"group__transport.html#ga3eb018b426d168de8c8d9b3441be036c":[5,0,0,27,50],
+"group__transport.html#ga3eb018b426d168de8c8d9b3441be036c":[3,0,8,51],
+"group__transport.html#ga3ef8b0032b2a012c697e853e363338ea":[3,0,8,46],
+"group__transport.html#ga3ef8b0032b2a012c697e853e363338ea":[5,0,0,27,45],
+"group__transport.html#ga46552ed46e59de6530d2eee03707a51b":[5,0,0,27,31],
+"group__transport.html#ga46552ed46e59de6530d2eee03707a51b":[3,0,8,32],
+"group__transport.html#ga4695788da8491f0c7104bfe36634ff94":[3,0,8,5],
+"group__transport.html#ga4695788da8491f0c7104bfe36634ff94":[5,0,0,27,5],
+"group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85":[5,0,0,27,40],
+"group__transport.html#ga4a9e6c6b207c41647ff988b5ae090d85":[3,0,8,41],
+"group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b":[5,0,0,27,41],
+"group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b":[3,0,8,42],
+"group__transport.html#ga51573625b6940884fed214b615f42e0f":[3,0,8,33],
+"group__transport.html#ga51573625b6940884fed214b615f42e0f":[5,0,0,27,32],
+"group__transport.html#ga55c589d9b3e69057b130036c3c2173df":[3,0,8,53],
+"group__transport.html#ga55c589d9b3e69057b130036c3c2173df":[5,0,0,27,52],
+"group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694":[5,0,0,27,51],
+"group__transport.html#ga65e4c70675f7e94dfaa9d58b2a590694":[3,0,8,52],
+"group__transport.html#ga6980396c3d890b86656167c3a063eee7":[3,0,8,35],
+"group__transport.html#ga6980396c3d890b86656167c3a063eee7":[5,0,0,27,34],
+"group__transport.html#ga6ab28051242631d9bea4814e8670ab90":[5,0,0,27,9],
+"group__transport.html#ga6ab28051242631d9bea4814e8670ab90":[3,0,8,10],
+"group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58":[3,0,8,11],
+"group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58":[5,0,0,27,10],
+"group__transport.html#ga7065ad65f95c995a24e416edc95aead4":[3,0,8,3],
+"group__transport.html#ga7065ad65f95c995a24e416edc95aead4":[5,0,0,27,3],
+"group__transport.html#ga737021ca419e948932071aad2ad38c5b":[3,0,8,15],
+"group__transport.html#ga737021ca419e948932071aad2ad38c5b":[5,0,0,27,14],
+"group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7":[5,0,0,27,20],
+"group__transport.html#ga7eb7915459eb433e68ff5ce80c5020a7":[3,0,8,21],
+"group__transport.html#ga81adf1fd6fa28054f2f80c424aa98122":[5,0,0,27,44],
+"group__transport.html#ga81adf1fd6fa28054f2f80c424aa98122":[3,0,8,45],
+"group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d":[5,0,0,27,12],
+"group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d":[3,0,8,13],
+"group__transport.html#ga8f080d7fb1e7fea2c93391d0b8f59773":[3,0,8,30],
+"group__transport.html#ga8f080d7fb1e7fea2c93391d0b8f59773":[5,0,0,27,29],
+"group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61":[3,0,8,56],
+"group__transport.html#ga92ce0b44ab956c182d646824b4e9ed61":[5,0,0,27,55],
+"group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d":[3,0,8,38],
+"group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d":[5,0,0,27,37],
+"group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333":[5,0,0,27,39],
+"group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333":[3,0,8,40],
+"group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289":[5,0,0,27,43],
+"group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289":[3,0,8,44],
+"group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56":[5,0,0,27,19],
+"group__transport.html#gaa83f8c30fc0e7518c6ef214bb7b4ea56":[3,0,8,20],
+"group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072":[5,0,0,27,48],
+"group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072":[3,0,8,49],
+"group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef":[3,0,8,50],
+"group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef":[5,0,0,27,49],
+"group__transport.html#gab8e04b4c128379ff27e6b801c0bce494":[3,0,8,2],
+"group__transport.html#gab8e04b4c128379ff27e6b801c0bce494":[5,0,0,27,2],
+"group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5":[3,0,8,37],
+"group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5":[5,0,0,27,36],
+"group__transport.html#gabdd6d56837a028097b1676350d65a864":[5,0,0,27,24],
+"group__transport.html#gabdd6d56837a028097b1676350d65a864":[3,0,8,25],
+"group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052":[3,0,8,29],
+"group__transport.html#gac14e93cc5e8bc949fe7a0800ebd6e052":[5,0,0,27,28],
+"group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74":[5,0,0,27,23],
+"group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74":[3,0,8,24],
+"group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8":[3,0,8,7],
+"group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8":[5,0,0,29,17],
+"group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34":[5,0,0,27,15],
+"group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34":[3,0,8,16],
+"group__transport.html#gac5bebd26c0942bc17d7fad36577110f8":[5,0,0,27,8],
+"group__transport.html#gac5bebd26c0942bc17d7fad36577110f8":[3,0,8,9],
+"group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f":[5,0,0,27,26],
+"group__transport.html#gac773c1b9226783f36e2f2d4770e90e3f":[3,0,8,27],
+"group__transport.html#gad603e8d72578bcedd2d9235f74f28f37":[3,0,8,26],
+"group__transport.html#gad603e8d72578bcedd2d9235f74f28f37":[5,0,0,27,25],
+"group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e":[3,0,8,39],
+"group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e":[5,0,0,27,38],
+"group__transport.html#gae8f32e46e94953bab10bee530eee9044":[5,0,0,27,0],
+"group__transport.html#gae8f32e46e94953bab10bee530eee9044":[3,0,8,0],
+"group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3":[5,0,0,27,6],
+"group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3":[3,0,8,6],
+"group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34":[5,0,0,27,13],
+"group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34":[3,0,8,14],
+"group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa":[5,0,0,27,16],
+"group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa":[3,0,8,17],
+"group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77":[3,0,8,8],
+"group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77":[5,0,0,27,7],
+"group__transport.html#gafb1c98602d17524eb40e48bf610362d7":[5,0,0,27,35],
+"group__transport.html#gafb1c98602d17524eb40e48bf610362d7":[3,0,8,36],
+"group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8":[3,0,8,1],
+"group__transport.html#gafde0eb3c73fb98816f4238d42d48f3d8":[5,0,0,27,1],
+"group__transport.html#gaff7c08aeb92596ad9d269468d1557647":[5,0,0,27,30],
+"group__transport.html#gaff7c08aeb92596ad9d269468d1557647":[3,0,8,31],
+"group__types.html":[3,1],
+"group__url.html":[3,5],
+"group__url.html#ga04bdbeb6e80fe9c284bd53869106376e":[5,0,0,30,8],
+"group__url.html#ga1a084548853885c874b1d0d435ef947c":[5,0,0,30,16],
+"group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b":[5,0,0,30,4],
+"group__url.html#ga2f7548b8247ebddc8be3f0f5ebce151b":[3,5,4],
+"group__url.html#ga389ea60e7d9bb206d60e383eaa8df3b4":[5,0,0,30,9],
+"group__url.html#ga3b9cbf8a77179b15b2100870913d6aaf":[5,0,0,30,14],
+"group__url.html#ga52876d19683cc9fb3318e29b297a0dfa":[5,0,0,30,15],
+"group__url.html#ga53ec7ab65dddea7383e64c6b2c58104e":[5,0,0,30,7],
+"group__url.html#ga5eb2682f856fa187bc99f0f46774aeb8":[5,0,0,30,12],
+"group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d":[3,5,5],
+"group__url.html#ga7e10d384560ab3e2bc9bbe219883e21d":[5,0,0,30,5],
+"group__url.html#ga8b19840fe7ff1166c6583a7445eed325":[3,5,1],
+"group__url.html#ga8b19840fe7ff1166c6583a7445eed325":[5,0,0,30,1],
+"group__url.html#ga9162f3f1ba4bc374f079f9c01c3dee99":[5,0,0,30,6],
+"group__url.html#ga9939dda9f21f76d336ea7618fb6c4f2c":[5,0,0,30,10],
+"group__url.html#gaaa9f2f29b90525fbf73739cae8b84776":[3,5,2],
+"group__url.html#gaaa9f2f29b90525fbf73739cae8b84776":[5,0,0,30,2],
+"group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1":[5,0,0,30,3],
+"group__url.html#gab65d8b2c49f5e3f720cea8a3c1a1e6d1":[3,5,3],
+"group__url.html#gabaa60d37795438556e4db952a50e35a7":[5,0,0,30,11],
+"group__url.html#gac72ebae7180d58003d489f2e4005d0c1":[5,0,0,30,17],
+"group__url.html#gafbe4340c29b1abd7394767456ad3b8ea":[3,5,0],
+"group__url.html#gafbe4340c29b1abd7394767456ad3b8ea":[5,0,0,30,0],
+"group__url.html#gafefe82e512fbdede2f1f539cf07b8bff":[5,0,0,30,13],
+"handlers_8h_source.html":[5,0,0,10],
+"import__export_8h_source.html":[5,0,0,11],
 "index.html":[],
+"index.html":[0],
 "io_page.html":[1],
-"link_8h.html":[4,0,0,8],
-"link_8h_source.html":[4,0,0,8],
-"listener_8h.html":[4,0,0,9],
-"listener_8h_source.html":[4,0,0,9],
-"message_8h.html":[4,0,0,10],
-"message_8h_source.html":[4,0,0,10],
-"messenger_8h.html":[4,0,0,11],
-"messenger_8h_source.html":[4,0,0,11],
-"modules.html":[2],
-"netaddr_8h.html":[4,0,0,12],
-"netaddr_8h_source.html":[4,0,0,12],
+"link_8h.html":[5,0,0,12],
+"link_8h_source.html":[5,0,0,12],
+"listener_8h.html":[5,0,0,13],
+"listener_8h_source.html":[5,0,0,13],
+"log_8h_source.html":[5,0,0,14],
+"message_8h.html":[5,0,0,15],
+"message_8h_source.html":[5,0,0,15],
+"messenger_8h.html":[5,0,0,16],
+"messenger_8h_source.html":[5,0,0,16],
+"modules.html":[3],
+"netaddr_8h.html":[5,0,0,17],
+"netaddr_8h_source.html":[5,0,0,17],
+"object_8h_source.html":[5,0,0,18],
 "pages.html":[],
-"proactor_8h.html":[4,0,0,13],
-"proactor_8h_source.html":[4,0,0,13],
-"sasl_8h.html":[4,0,0,14],
-"sasl_8h_source.html":[4,0,0,14],
-"session_8h.html":[4,0,0,15],
-"session_8h_source.html":[4,0,0,15],
-"ssl_8h.html":[4,0,0,16],
-"ssl_8h_source.html":[4,0,0,16],
-"terminus_8h.html":[4,0,0,17],
-"terminus_8h_source.html":[4,0,0,17],
-"transport_8h.html":[4,0,0,18],
-"transport_8h_source.html":[4,0,0,18],
-"types_8h.html":[4,0,0,19],
-"types_8h_source.html":[4,0,0,19],
-"url_8h.html":[4,0,0,20],
-"url_8h_source.html":[4,0,0,20]
+"proactor_8h.html":[5,0,0,19],
+"proactor_8h_source.html":[5,0,0,19],
+"reactor_8h_source.html":[5,0,0,20],
+"receive_8c-example.html":[6,2],
+"sasl-plugin_8h_source.html":[5,0,0,21],
+"sasl_8h.html":[5,0,0,22],
+"sasl_8h_source.html":[5,0,0,22],
+"selectable_8h_source.html":[5,0,0,23],
+"send_8c-example.html":[6,3],
+"session_8h.html":[5,0,0,24],
+"session_8h_source.html":[5,0,0,24],
+"ssl_8h.html":[5,0,0,25],
+"ssl_8h_source.html":[5,0,0,25],
+"terminus_8h.html":[5,0,0,26],
+"terminus_8h_source.html":[5,0,0,26],
+"transport_8h.html":[5,0,0,27],
+"transport_8h_source.html":[5,0,0,27],
+"type__compat_8h_source.html":[5,0,0,28],
+"types_8h.html":[5,0,0,29],
+"types_8h_source.html":[5,0,0,29],
+"url_8h.html":[5,0,0,30],
+"url_8h_source.html":[5,0,0,30]
 };

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.html b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.html
index a7d90c8..d003dcd 100755
--- a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.html
@@ -114,20 +114,34 @@ typedef struct <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c8
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="func-members"></a>
 Functions</h2></td></tr>
 <tr class="memitem:ga9f6a27999303c6082edc581f880de37c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *addr, char *buf, size_t size)</td></tr>
-<tr class="memdesc:ga9f6a27999303c6082edc581f880de37c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a network address as a human-readable string in <code>buf</code>.  <a href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">More...</a><br /></td></tr>
+<tr class="memdesc:ga9f6a27999303c6082edc581f880de37c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a network address string in <code>buf</code>.  <a href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">More...</a><br /></td></tr>
 <tr class="separator:ga9f6a27999303c6082edc581f880de37c"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
-<tr class="memdesc:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">More...</a><br /></td></tr>
-<tr class="separator:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
-<tr class="memdesc:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the remote address of a transport.  <a href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">More...</a><br /></td></tr>
-<tr class="separator:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8bcff2f30c1608c1d883eab461cc9148"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">pn_transport_local_addr</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="memdesc:ga8bcff2f30c1608c1d883eab461cc9148"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">More...</a><br /></td></tr>
+<tr class="separator:ga8bcff2f30c1608c1d883eab461cc9148"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga3a6d4bda7cfae2780dbb587443eded39"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">pn_transport_remote_addr</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="memdesc:ga3a6d4bda7cfae2780dbb587443eded39"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the local address of a transport.  <a href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">More...</a><br /></td></tr>
+<tr class="separator:ga3a6d4bda7cfae2780dbb587443eded39"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">pn_listener_addr</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
+<tr class="memdesc:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the listening addresses of a listener.  <a href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">More...</a><br /></td></tr>
+<tr class="separator:gacdbda4ea3dc040af5a4c1d633ddd7cd9"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga6163449ac3b87782628448f192930eb0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
+<tr class="separator:ga6163449ac3b87782628448f192930eb0"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const struct sockaddr *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">pn_netaddr_sockaddr</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
 <tr class="memdesc:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="mdescLeft">&#160;</td><td class="mdescRight">On POSIX or Windows, get the underlying <code>struct sockaddr</code>.  <a href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">More...</a><br /></td></tr>
 <tr class="separator:ga00b1a40af2d837915d21cdb52ccb0c58"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN size_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">pn_netaddr_socklen</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na)</td></tr>
 <tr class="memdesc:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="mdescLeft">&#160;</td><td class="mdescRight">On POSIX or Windows, get the size of the underlying <code>struct sockaddr</code>.  <a href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">More...</a><br /></td></tr>
 <tr class="separator:gaddaf2b0b3e107d100e4c3658116a6c3c"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">pn_netaddr_host_port</a> (const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na, char *host, size_t hlen, char *port, size_t plen)</td></tr>
+<tr class="memdesc:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the host and port name from na as separate strings.  <a href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">More...</a><br /></td></tr>
+<tr class="separator:ga8cdeab8554e7d376a422dae8ac6d474b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="separator:ga7edab5e295c55e1c2169e39aaa082f8b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t)</td></tr>
+<tr class="separator:ga59fa5ba7adc39bc8549645d5d33082c0"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga955471a53dd486a6f227d8d57322a44c"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN const <a class="el" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">pn_netaddr_listening</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
+<tr class="separator:ga955471a53dd486a6f227d8d57322a44c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p><b>Unsettled API</b> - The network address of a proactor transport. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.js b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.js
index ea7a608..300d23c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h.js
@@ -2,8 +2,14 @@ var netaddr_8h =
 [
     [ "pn_netaddr_t", "group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c", null ],
     [ "pn_netaddr_str", "group__proactor.html#ga9f6a27999303c6082edc581f880de37c", null ],
+    [ "pn_transport_local_addr", "group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148", null ],
+    [ "pn_transport_remote_addr", "group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39", null ],
+    [ "pn_listener_addr", "group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9", null ],
+    [ "pn_netaddr_next", "group__proactor.html#ga6163449ac3b87782628448f192930eb0", null ],
+    [ "pn_netaddr_sockaddr", "group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58", null ],
+    [ "pn_netaddr_socklen", "group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c", null ],
+    [ "pn_netaddr_host_port", "group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b", null ],
     [ "pn_netaddr_local", "group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b", null ],
     [ "pn_netaddr_remote", "group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0", null ],
-    [ "pn_netaddr_sockaddr", "group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58", null ],
-    [ "pn_netaddr_socklen", "group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c", null ]
+    [ "pn_netaddr_listening", "group__proactor.html#ga955471a53dd486a6f227d8d57322a44c", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/netaddr_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h_source.html
index 4ef1833..7fa8189 100755
--- a/content/releases/qpid-proton-master/proton/c/api/netaddr_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/netaddr_8h_source.html
@@ -93,14 +93,21 @@ $(document).ready(function(){initNavTree('netaddr_8h_source.html','');});
 <div class="title">netaddr.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="netaddr_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_NETADDR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_NETADDR_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#1
 60;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="
 comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * specific
  language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno"><a class="line" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">   38</a></span>&#160;<span class
 ="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;PNP_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *addr, <span class="keywordtype">char</span> *buf, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;PNP_EXTERN <span class="keyword">
 const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<
 span class="keyword">struct </span>sockaddr;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;PNP_EXTERN <span class="keyword">const</span> <span class="keyword">struct </span>sockaddr *<a class="code" href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">pn_netaddr_sockaddr</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;PNP_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">pn_netaddr_socklen</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *n
 a);</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif // PROTON_NETADDR_H</span></div><div class="ttc" id="group__proactor_html_ga9f6a27999303c6082edc581f880de37c"><div class="ttname"><a href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a></div><div class="ttdeci">PNP_EXTERN int pn_netaddr_str(const pn_netaddr_t *addr, char *buf, size_t size)</div><div class="ttdoc">Format a network address as a human-readable string in buf. </div></div>
+<a href="netaddr_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_NETADDR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_NETADDR_H</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#1
 60;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="
 comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * specific
  language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;</div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00027"><
 /a><span class="lineno">   27</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno"><a class="line" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">   42</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;PNP_EXTERN <span class="keywordtype">int</span> <a class="cod
 e" href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *addr, <span class="keywordtype">char</span> *buf, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">pn_transport_local_addr</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&
 #160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">pn_transport_remote_addr</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">pn_listener_addr</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00086"><
 /a><span class="lineno">   86</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="keyword">struct </span>sockaddr;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PNP_EXTERN <span class="keyword">const</span> <span class="keyword">struct </span>sockaddr *<a class="code" href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">pn_netaddr_sockaddr</a>(<
 span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;PNP_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">pn_netaddr_socklen</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *na);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PNP_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">pn_netaddr_host_port</a>(<span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d82
 0cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a>* na, <span class="keywordtype">char</span> *host, <span class="keywordtype">size_t</span> hlen, <span class="keywordtype">char</span> *port, <span class="keywordtype">size_t</span> plen);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="g
 roup__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNP_EXTERN <span class="keyword">const</span> <a class="code" href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a> *<a class="code" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">pn_netaddr_listening</a>(<a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;}</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&
 #160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* PROTON_NETADDR_H */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> types.h:420</div></div>
+<div class="ttc" id="group__proactor_html_ga9f6a27999303c6082edc581f880de37c"><div class="ttname"><a href="group__proactor.html#ga9f6a27999303c6082edc581f880de37c">pn_netaddr_str</a></div><div class="ttdeci">PNP_EXTERN int pn_netaddr_str(const pn_netaddr_t *addr, char *buf, size_t size)</div><div class="ttdoc">Format a network address string in buf. </div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
-<div class="ttc" id="group__proactor_html_ga7edab5e295c55e1c2169e39aaa082f8b"><div class="ttname"><a href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_local(pn_transport_t *t)</div><div class="ttdoc">Get the local address of a transport. </div></div>
-<div class="ttc" id="group__proactor_html_ga59fa5ba7adc39bc8549645d5d33082c0"><div class="ttname"><a href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_remote(pn_transport_t *t)</div><div class="ttdoc">Get the remote address of a transport. </div></div>
-<div class="ttc" id="group__proactor_html_ga79d820cd3ad391cc5207c83dbb373a9c"><div class="ttname"><a href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a></div><div class="ttdeci">struct pn_netaddr_t pn_netaddr_t</div><div class="ttdoc">Unsettled API - The network address of a proactor transport. </div><div class="ttdef"><b>Definition:</b> netaddr.h:38</div></div>
+<div class="ttc" id="group__proactor_html_ga8cdeab8554e7d376a422dae8ac6d474b"><div class="ttname"><a href="group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b">pn_netaddr_host_port</a></div><div class="ttdeci">PNP_EXTERN int pn_netaddr_host_port(const pn_netaddr_t *na, char *host, size_t hlen, char *port, size_t plen)</div><div class="ttdoc">Get the host and port name from na as separate strings. </div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
+<div class="ttc" id="group__proactor_html_ga6163449ac3b87782628448f192930eb0"><div class="ttname"><a href="group__proactor.html#ga6163449ac3b87782628448f192930eb0">pn_netaddr_next</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_next(const pn_netaddr_t *na)</div></div>
+<div class="ttc" id="group__proactor_html_gacdbda4ea3dc040af5a4c1d633ddd7cd9"><div class="ttname"><a href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9">pn_listener_addr</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_listener_addr(pn_listener_t *l)</div><div class="ttdoc">Get the listening addresses of a listener. </div></div>
+<div class="ttc" id="group__proactor_html_ga7edab5e295c55e1c2169e39aaa082f8b"><div class="ttname"><a href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_local(pn_transport_t *t)</div></div>
+<div class="ttc" id="group__proactor_html_ga59fa5ba7adc39bc8549645d5d33082c0"><div class="ttname"><a href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_remote(pn_transport_t *t)</div></div>
+<div class="ttc" id="group__proactor_html_ga3a6d4bda7cfae2780dbb587443eded39"><div class="ttname"><a href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39">pn_transport_remote_addr</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_transport_remote_addr(pn_transport_t *t)</div><div class="ttdoc">Get the local address of a transport. </div></div>
+<div class="ttc" id="group__proactor_html_ga79d820cd3ad391cc5207c83dbb373a9c"><div class="ttname"><a href="group__proactor.html#ga79d820cd3ad391cc5207c83dbb373a9c">pn_netaddr_t</a></div><div class="ttdeci">struct pn_netaddr_t pn_netaddr_t</div><div class="ttdoc">Unsettled API - The network address of a proactor transport. </div><div class="ttdef"><b>Definition:</b> netaddr.h:42</div></div>
 <div class="ttc" id="group__proactor_html_ga00b1a40af2d837915d21cdb52ccb0c58"><div class="ttname"><a href="group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58">pn_netaddr_sockaddr</a></div><div class="ttdeci">PNP_EXTERN const struct sockaddr * pn_netaddr_sockaddr(const pn_netaddr_t *na)</div><div class="ttdoc">On POSIX or Windows, get the underlying struct sockaddr. </div></div>
+<div class="ttc" id="group__proactor_html_ga8bcff2f30c1608c1d883eab461cc9148"><div class="ttname"><a href="group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148">pn_transport_local_addr</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_transport_local_addr(pn_transport_t *t)</div><div class="ttdoc">Get the local address of a transport. </div></div>
 <div class="ttc" id="group__proactor_html_gaddaf2b0b3e107d100e4c3658116a6c3c"><div class="ttname"><a href="group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c">pn_netaddr_socklen</a></div><div class="ttdeci">PNP_EXTERN size_t pn_netaddr_socklen(const pn_netaddr_t *na)</div><div class="ttdoc">On POSIX or Windows, get the size of the underlying struct sockaddr. </div></div>
+<div class="ttc" id="group__proactor_html_ga955471a53dd486a6f227d8d57322a44c"><div class="ttname"><a href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">pn_netaddr_listening</a></div><div class="ttdeci">PNP_EXTERN const pn_netaddr_t * pn_netaddr_listening(pn_listener_t *l)</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->


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


[40/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/link_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/link_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/link_8h_source.html
index 2389e1b..4566ef1 100755
--- a/content/releases/qpid-proton-master/proton/c/api/link_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/link_8h_source.html
@@ -93,19 +93,19 @@ $(document).ready(function(){initNavTree('link_8h_source.html','');});
 <div class="title">link.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="link_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LINK_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LINK_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements. 
  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment
 "> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><di
 v class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</s
 pan>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="terminus_8h.html">proton/terminus.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor"
 >#ifdef __cplusplus</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga469bef2e81c53e85899ffbb277616a8c">pn_sender</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00072"></a><span 
 class="lineno">   72</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f">pn_receiver</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7">pn_link_free</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PN_EXTERN <span 
 class="keywordtype">void</span> *<a class="code" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">pn_link_attachments</a>(<a class="code" href
 ="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__link.html#gaa44112980ebabbb5cbd002670073a751">pn_link_name</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00134"></a><span class="lineno">  134<
 /span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#gae7045dd02f2c9450ff8737e005628d81">pn_link_is_receiver</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__link.html#gad502b38bc184ad0bfaa86dede81f62c9">pn_link_state</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;PN_EXTERN <a class="code" h
 ref="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__link.html#ga52c99044eabb7712efa2f1098c760804">pn_link_condition</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_c
 ondition_t</a> *<a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga7c9434c
 40eb653f007ff5721e2ebf73e">pn_link_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;PN_EXTERN
  <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d">pn_link_close</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b">pn_link_detach</a>(<a class="code" href="group__link.html#ga89dad3aa793432
 9a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line">
 <a name="l00296"></a><span class="lineno">  296</span>&#160;</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#gadf6b8ff6223465f21a481e9287f60671">pn_link_remote_source</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00309"></a><span class="lineno">  309</span>&#160;</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#gabf61668a66ae189dbb4820da6ee30d90">pn_link_remote_target</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00322"></a><span class="lineno">  322</sp
 an>&#160;</div><div class="line"><a name="l00338"></a><span class="lineno">  338</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#gad7e426b0cc4759568b3fd2b4fb176260">pn_link_current</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00339"></a><span class="lineno">  339</span>&#160;</div><div class="line"><a name="l00364"></a><span class="lineno">  364</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00365"></a><span class="lineno">  365</span>&#160;</div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;PN_EXTERN <span class="keyword
 type">int</span> <a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00390"></a><span class="lineno">  390</span>&#160;</div><div class="line"><a name="l00403"></a><span class="lineno">  403</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9">pn_link_queued</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00404"></a><span class="lineno">  404</span>&#160;</div><div class="line"><a name="l00416"></a><span class="lineno">  416</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb">pn_link_remote_credit</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c63668
 7bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00417"></a><span class="lineno">  417</span>&#160;</div><div class="line"><a name="l00430"></a><span class="lineno">  430</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac">pn_link_get_drain</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00431"></a><span class="lineno">  431</span>&#160;</div><div class="line"><a name="l00451"></a><span class="lineno">  451</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23">pn_link_drained</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00452"></a><span class="lineno">  452</span>&#160;</div><div class="line"><a name="l00464"></a><span class="lineno">  464
 </span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga7f1742528b32c3c9609b97a3ed449639">pn_link_available</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00465"></a><span class="lineno">  465</span>&#160;</div><div class="line"><a name="l00474"></a><span class="lineno"><a class="line" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">  474</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00475"></a><span class="lineno"><a class="line" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade">  475</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade">PN_SND_UNSETTLED</a> = 0, </div><div class="line"><a name="l00477"></a><span class="lineno"><a class="line" href="gro
 up__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0">  477</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0">PN_SND_SETTLED</a> = 1, </div><div class="line"><a name="l00479"></a><span class="lineno"><a class="line" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">  479</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">PN_SND_MIXED</a> = 2 </div><div class="line"><a name="l00481"></a><span class="lineno">  481</span>&#160;} <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a>;</div><div class="line"><a name="l00482"></a><span class="lineno">  482</span>&#160;</div><div class="line"><a name="l00491"></a><span class="lineno"><a class="line" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">  491</a></span>
 &#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00492"></a><span class="lineno"><a class="line" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262">  492</a></span>&#160;  <a class="code" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262">PN_RCV_FIRST</a> = 0,  </div><div class="line"><a name="l00494"></a><span class="lineno"><a class="line" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3">  494</a></span>&#160;  <a class="code" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3">PN_RCV_SECOND</a> = 1  </div><div class="line"><a name="l00496"></a><span class="lineno">  496</span>&#160;} <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a>;</div><div class="line"><a name="l00497"></a><span class="lineno">  497
 </span>&#160;</div><div class="line"><a name="l00504"></a><span class="lineno">  504</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> <a class="code" href="group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6">pn_link_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00505"></a><span class="lineno">  505</span>&#160;</div><div class="line"><a name="l00512"></a><span class="lineno">  512</span>&#160;PN_EXTERN <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> <a class="code" href="group__link.html#ga0bc65ff494e2860e6227f68c72468101">pn_link_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00513"></a><span class="lineno">  513</span>&#160;</div><div class="line"><a nam
 e="l00520"></a><span class="lineno">  520</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga677c416a6365cedd23b43043dff0b89f">pn_link_set_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> mode);</div><div class="line"><a name="l00521"></a><span class="lineno">  521</span>&#160;</div><div class="line"><a name="l00528"></a><span class="lineno">  528</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gab6441a917c291e68984405057eb56ab8">pn_link_set_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> mode);</div><div class="line"><a name="l00529"></a><span class="lin
 eno">  529</span>&#160;</div><div class="line"><a name="l00536"></a><span class="lineno">  536</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> <a class="code" href="group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f">pn_link_remote_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00537"></a><span class="lineno">  537</span>&#160;</div><div class="line"><a name="l00544"></a><span class="lineno">  544</span>&#160;PN_EXTERN <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> <a class="code" href="group__link.html#ga378e4bb5a0519a75c3c151c15809dda5">pn_link_remote_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00545"></a><span class="lineno">  545</span>&#160;</div>
 <div class="line"><a name="l00552"></a><span class="lineno">  552</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1">pn_link_unsettled</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00553"></a><span class="lineno">  553</span>&#160;</div><div class="line"><a name="l00560"></a><span class="lineno">  560</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#ga6206e3d4efe0ebe0491955006930fa18">pn_unsettled_head</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00561"></a><span class="lineno">  561</span>&#160;</div><div class="line"><a name="l00568"></a><span class="lineno">  568</span>&#160;PN_EXTERN <a class="code" href="group__del
 ivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce">pn_unsettled_next</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00569"></a><span class="lineno">  569</span>&#160;</div><div class="line"><a name="l00577"></a><span class="lineno">  577</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2">pn_link_offered</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00578"></a><span class="lineno">  578</span>&#160;</div><div class="line"><a name="l00587"></a><span class="lineno">  587</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9">pn_link_sen
 d</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00588"></a><span class="lineno">  588</span>&#160;</div><div class="line"><a name="l00595"></a><span class="lineno">  595</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00596"></a><span class="lineno">  596</span>&#160;</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df">pn_link_drain</a>(<a clas
 s="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00607"></a><span class="lineno">  607</span>&#160;</div><div class="line"><a name="l00614"></a><span class="lineno">  614</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaeb417e6b7e99c76f61549f5ed5519395">pn_link_set_drain</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">bool</span> drain);</div><div class="line"><a name="l00615"></a><span class="lineno">  615</span>&#160;</div><div class="line"><a name="l00635"></a><span class="lineno">  635</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_recv</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtyp
 e">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00636"></a><span class="lineno">  636</span>&#160;</div><div class="line"><a name="l00646"></a><span class="lineno">  646</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga4a821eaf6298b94522572fad73b8e2d1">pn_link_draining</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver);</div><div class="line"><a name="l00647"></a><span class="lineno">  647</span>&#160;</div><div class="line"><a name="l00656"></a><span class="lineno">  656</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__link.html#gac282341dacff892eba8e224eca5c5c52">pn_link_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00657"></a><span class="lineno">  657</span>&#160;</div><div class="line"><a name="l00666"></a><sp
 an class="lineno">  666</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga2421a9ddebba208338412dea365cf6ad">pn_link_set_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, uint64_t size);</div><div class="line"><a name="l00667"></a><span class="lineno">  667</span>&#160;</div><div class="line"><a name="l00676"></a><span class="lineno">  676</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d">pn_link_remote_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00677"></a><span class="lineno">  677</span>&#160;</div><div class="line"><a name="l00682"></a><span class="lineno">  682</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00683"></a><span class="lineno">  683</span>&#
 160;}</div><div class="line"><a name="l00684"></a><span class="lineno">  684</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00685"></a><span class="lineno">  685</span>&#160;</div><div class="line"><a name="l00686"></a><span class="lineno">  686</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* link.h */</span><span class="preprocessor"></span></div><div class="line"><a name="l00687"></a><span class="lineno">  687</span>&#160;</div><div class="ttc" id="group__link_html_ga2c8985a9d44a813ab1739a91ae3708a3"><div class="ttname"><a href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a></div><div class="ttdeci">pn_terminus_t * pn_link_source(pn_link_t *link)</div><div class="ttdoc">Access the locally defined source definition for a link. </div></div>
+<a href="link_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LINK_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LINK_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements. 
  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment
 "> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><di
 v class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</s
 pan>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="terminus_8h.html">proton/terminus.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor"
 >#ifdef __cplusplus</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga469bef2e81c53e85899ffbb277616a8c">pn_sender</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00072"></a><span 
 class="lineno">   72</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f">pn_receiver</a>(<a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *session, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7">pn_link_free</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PN_EXTERN <span 
 class="keywordtype">void</span> *<a class="code" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">pn_link_attachments</a>(<a class="code" href
 ="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__link.html#gaa44112980ebabbb5cbd002670073a751">pn_link_name</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00134"></a><span class="lineno">  134<
 /span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#gae7045dd02f2c9450ff8737e005628d81">pn_link_is_receiver</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;PN_EXTERN <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> <a class="code" href="group__link.html#gad502b38bc184ad0bfaa86dede81f62c9">pn_link_state</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;PN_EXTERN <a class="code" h
 ref="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *<a class="code" href="group__link.html#ga52c99044eabb7712efa2f1098c760804">pn_link_condition</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PN_EXTERN <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_c
 ondition_t</a> *<a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PN_EXTERN <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *<a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga7c9434c
 40eb653f007ff5721e2ebf73e">pn_link_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a> state);</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;PN_EXTERN
  <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d">pn_link_close</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b">pn_link_detach</a>(<a class="code" href="group__link.html#ga89dad3aa793432
 9a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line">
 <a name="l00296"></a><span class="lineno">  296</span>&#160;</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#gadf6b8ff6223465f21a481e9287f60671">pn_link_remote_source</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00309"></a><span class="lineno">  309</span>&#160;</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;PN_EXTERN <a class="code" href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a> *<a class="code" href="group__link.html#gabf61668a66ae189dbb4820da6ee30d90">pn_link_remote_target</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00322"></a><span class="lineno">  322</sp
 an>&#160;</div><div class="line"><a name="l00338"></a><span class="lineno">  338</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#gad7e426b0cc4759568b3fd2b4fb176260">pn_link_current</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00339"></a><span class="lineno">  339</span>&#160;</div><div class="line"><a name="l00364"></a><span class="lineno">  364</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00365"></a><span class="lineno">  365</span>&#160;</div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;PN_EXTERN <span class="keyword
 type">int</span> <a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00390"></a><span class="lineno">  390</span>&#160;</div><div class="line"><a name="l00403"></a><span class="lineno">  403</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9">pn_link_queued</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00404"></a><span class="lineno">  404</span>&#160;</div><div class="line"><a name="l00416"></a><span class="lineno">  416</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb">pn_link_remote_credit</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c63668
 7bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00417"></a><span class="lineno">  417</span>&#160;</div><div class="line"><a name="l00430"></a><span class="lineno">  430</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac">pn_link_get_drain</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00431"></a><span class="lineno">  431</span>&#160;</div><div class="line"><a name="l00451"></a><span class="lineno">  451</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23">pn_link_drained</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00452"></a><span class="lineno">  452</span>&#160;</div><div class="line"><a name="l00464"></a><span class="lineno">  464
 </span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#ga7f1742528b32c3c9609b97a3ed449639">pn_link_available</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00465"></a><span class="lineno">  465</span>&#160;</div><div class="line"><a name="l00474"></a><span class="lineno"><a class="line" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">  474</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00475"></a><span class="lineno"><a class="line" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade">  475</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade">PN_SND_UNSETTLED</a> = 0, </div><div class="line"><a name="l00477"></a><span class="lineno"><a class="line" href="gro
 up__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0">  477</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0">PN_SND_SETTLED</a> = 1, </div><div class="line"><a name="l00479"></a><span class="lineno"><a class="line" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">  479</a></span>&#160;  <a class="code" href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">PN_SND_MIXED</a> = 2 </div><div class="line"><a name="l00481"></a><span class="lineno">  481</span>&#160;} <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a>;</div><div class="line"><a name="l00482"></a><span class="lineno">  482</span>&#160;</div><div class="line"><a name="l00491"></a><span class="lineno"><a class="line" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">  491</a></span>
 &#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00492"></a><span class="lineno"><a class="line" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262">  492</a></span>&#160;  <a class="code" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262">PN_RCV_FIRST</a> = 0,  </div><div class="line"><a name="l00494"></a><span class="lineno"><a class="line" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3">  494</a></span>&#160;  <a class="code" href="group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3">PN_RCV_SECOND</a> = 1  </div><div class="line"><a name="l00496"></a><span class="lineno">  496</span>&#160;} <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a>;</div><div class="line"><a name="l00497"></a><span class="lineno">  497
 </span>&#160;</div><div class="line"><a name="l00504"></a><span class="lineno">  504</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> <a class="code" href="group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6">pn_link_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00505"></a><span class="lineno">  505</span>&#160;</div><div class="line"><a name="l00512"></a><span class="lineno">  512</span>&#160;PN_EXTERN <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> <a class="code" href="group__link.html#ga0bc65ff494e2860e6227f68c72468101">pn_link_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00513"></a><span class="lineno">  513</span>&#160;</div><div class="line"><a nam
 e="l00520"></a><span class="lineno">  520</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga677c416a6365cedd23b43043dff0b89f">pn_link_set_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> mode);</div><div class="line"><a name="l00521"></a><span class="lineno">  521</span>&#160;</div><div class="line"><a name="l00528"></a><span class="lineno">  528</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gab6441a917c291e68984405057eb56ab8">pn_link_set_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> mode);</div><div class="line"><a name="l00529"></a><span class="lin
 eno">  529</span>&#160;</div><div class="line"><a name="l00536"></a><span class="lineno">  536</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> <a class="code" href="group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f">pn_link_remote_snd_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00537"></a><span class="lineno">  537</span>&#160;</div><div class="line"><a name="l00544"></a><span class="lineno">  544</span>&#160;PN_EXTERN <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> <a class="code" href="group__link.html#ga378e4bb5a0519a75c3c151c15809dda5">pn_link_remote_rcv_settle_mode</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00545"></a><span class="lineno">  545</span>&#160;</div>
 <div class="line"><a name="l00552"></a><span class="lineno">  552</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1">pn_link_unsettled</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00553"></a><span class="lineno">  553</span>&#160;</div><div class="line"><a name="l00560"></a><span class="lineno">  560</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#ga6206e3d4efe0ebe0491955006930fa18">pn_unsettled_head</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00561"></a><span class="lineno">  561</span>&#160;</div><div class="line"><a name="l00568"></a><span class="lineno">  568</span>&#160;PN_EXTERN <a class="code" href="group__del
 ivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce">pn_unsettled_next</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00569"></a><span class="lineno">  569</span>&#160;</div><div class="line"><a name="l00577"></a><span class="lineno">  577</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2">pn_link_offered</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00578"></a><span class="lineno">  578</span>&#160;</div><div class="line"><a name="l00587"></a><span class="lineno">  587</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9">pn_link_sen
 d</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *sender, <span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00588"></a><span class="lineno">  588</span>&#160;</div><div class="line"><a name="l00595"></a><span class="lineno">  595</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00596"></a><span class="lineno">  596</span>&#160;</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df">pn_link_drain</a>(<a clas
 s="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">int</span> credit);</div><div class="line"><a name="l00607"></a><span class="lineno">  607</span>&#160;</div><div class="line"><a name="l00614"></a><span class="lineno">  614</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#gaeb417e6b7e99c76f61549f5ed5519395">pn_link_set_drain</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtype">bool</span> drain);</div><div class="line"><a name="l00615"></a><span class="lineno">  615</span>&#160;</div><div class="line"><a name="l00640"></a><span class="lineno">  640</span>&#160;PN_EXTERN ssize_t <a class="code" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_recv</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver, <span class="keywordtyp
 e">char</span> *bytes, <span class="keywordtype">size_t</span> n);</div><div class="line"><a name="l00641"></a><span class="lineno">  641</span>&#160;</div><div class="line"><a name="l00651"></a><span class="lineno">  651</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__link.html#ga4a821eaf6298b94522572fad73b8e2d1">pn_link_draining</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *receiver);</div><div class="line"><a name="l00652"></a><span class="lineno">  652</span>&#160;</div><div class="line"><a name="l00661"></a><span class="lineno">  661</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__link.html#gac282341dacff892eba8e224eca5c5c52">pn_link_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00662"></a><span class="lineno">  662</span>&#160;</div><div class="line"><a name="l00671"></a><sp
 an class="lineno">  671</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__link.html#ga2421a9ddebba208338412dea365cf6ad">pn_link_set_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, uint64_t size);</div><div class="line"><a name="l00672"></a><span class="lineno">  672</span>&#160;</div><div class="line"><a name="l00681"></a><span class="lineno">  681</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d">pn_link_remote_max_message_size</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link);</div><div class="line"><a name="l00682"></a><span class="lineno">  682</span>&#160;</div><div class="line"><a name="l00687"></a><span class="lineno">  687</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00688"></a><span class="lineno">  688</span>&#
 160;}</div><div class="line"><a name="l00689"></a><span class="lineno">  689</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00690"></a><span class="lineno">  690</span>&#160;</div><div class="line"><a name="l00691"></a><span class="lineno">  691</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* link.h */</span><span class="preprocessor"></span></div><div class="line"><a name="l00692"></a><span class="lineno">  692</span>&#160;</div><div class="ttc" id="group__link_html_ga2c8985a9d44a813ab1739a91ae3708a3"><div class="ttname"><a href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a></div><div class="ttdeci">pn_terminus_t * pn_link_source(pn_link_t *link)</div><div class="ttdoc">Access the locally defined source definition for a link. </div></div>
 <div class="ttc" id="group__link_html_ga93824a3859c37463e44458cd2f63d31f"><div class="ttname"><a href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a></div><div class="ttdeci">bool pn_link_advance(pn_link_t *link)</div><div class="ttdoc">Advance the current delivery of a link to the next delivery on the link. </div></div>
 <div class="ttc" id="group__link_html_gadd3b8899fe023d3506fb88d228d6b1b7"><div class="ttname"><a href="group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7">pn_link_free</a></div><div class="ttdeci">void pn_link_free(pn_link_t *link)</div><div class="ttdoc">Free a link object. </div></div>
 <div class="ttc" id="group__link_html_ga9b2a9cfa00dfdae4e01bf75483433925"><div class="ttname"><a href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a></div><div class="ttdeci">pn_link_t * pn_link_next(pn_link_t *link, pn_state_t state)</div><div class="ttdoc">Retrieve the next link that matches the given state mask. </div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
 <div class="ttc" id="group__link_html_ga55428637f3b8c446efd5fea3f26c932d"><div class="ttname"><a href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a></div><div class="ttdeci">int pn_link_credit(pn_link_t *link)</div><div class="ttdoc">Get the credit balance for a link. </div></div>
 <div class="ttc" id="group__link_html_gaabaca3f5d03970a122240eebc588add6"><div class="ttname"><a href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a></div><div class="ttdeci">void pn_link_open(pn_link_t *link)</div><div class="ttdoc">Open a link. </div></div>
-<div class="ttc" id="group__link_html_ga376f2cc18bbd771d95aa8222586d19b2"><div class="ttname"><a href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a></div><div class="ttdeci">void pn_link_set_context(pn_link_t *link, void *context)</div></div>
+<div class="ttc" id="group__link_html_ga376f2cc18bbd771d95aa8222586d19b2"><div class="ttname"><a href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a></div><div class="ttdeci">void pn_link_set_context(pn_link_t *link, void *context)</div><div class="ttdoc">Deprecated - Use pn_link_attachments(). </div></div>
 <div class="ttc" id="group__link_html_ga40dd26f3d035c54056e2649aeb78d8ac"><div class="ttname"><a href="group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac">pn_link_get_drain</a></div><div class="ttdeci">bool pn_link_get_drain(pn_link_t *link)</div><div class="ttdoc">Get the drain flag for a link. </div></div>
-<div class="ttc" id="group__link_html_gaf6f11d778aa4622d8aa5db8962bb1f0a"><div class="ttname"><a href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a></div><div class="ttdeci">pn_error_t * pn_link_error(pn_link_t *link)</div></div>
+<div class="ttc" id="group__link_html_gaf6f11d778aa4622d8aa5db8962bb1f0a"><div class="ttname"><a href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a></div><div class="ttdeci">pn_error_t * pn_link_error(pn_link_t *link)</div><div class="ttdoc">Deprecated </div></div>
 <div class="ttc" id="group__link_html_ga6206e3d4efe0ebe0491955006930fa18"><div class="ttname"><a href="group__link.html#ga6206e3d4efe0ebe0491955006930fa18">pn_unsettled_head</a></div><div class="ttdeci">pn_delivery_t * pn_unsettled_head(pn_link_t *link)</div><div class="ttdoc">Get the first unsettled delivery for a link. </div></div>
 <div class="ttc" id="group__link_html_ga8b19ffdb7934940fa7c5fd75c5fe2d69"><div class="ttname"><a href="group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69">pn_link_attachments</a></div><div class="ttdeci">pn_record_t * pn_link_attachments(pn_link_t *link)</div><div class="ttdoc">Get the attachments that are associated with a link object. </div></div>
-<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:313</div></div>
+<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:311</div></div>
 <div class="ttc" id="group__link_html_gae7045dd02f2c9450ff8737e005628d81"><div class="ttname"><a href="group__link.html#gae7045dd02f2c9450ff8737e005628d81">pn_link_is_receiver</a></div><div class="ttdeci">bool pn_link_is_receiver(pn_link_t *link)</div><div class="ttdoc">Test if a link is a receiver. </div></div>
 <div class="ttc" id="group__link_html_gacef130ca5cc6eb3eec2dd48c8bf5c7e6"><div class="ttname"><a href="group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6">pn_link_snd_settle_mode</a></div><div class="ttdeci">pn_snd_settle_mode_t pn_link_snd_settle_mode(pn_link_t *link)</div><div class="ttdoc">Get the local sender settle mode for a link. </div></div>
 <div class="ttc" id="group__link_html_gac63e43305fb1a5e3b14399a9ddc8f24d"><div class="ttname"><a href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a></div><div class="ttdeci">pn_session_t * pn_link_session(pn_link_t *link)</div><div class="ttdoc">Get the parent session for a link object. </div></div>
@@ -116,8 +116,8 @@ $(document).ready(function(){initNavTree('link_8h_source.html','');});
 <div class="ttc" id="group__terminus_html_gad202baf5c904d6991e13521b7c93fdc2"><div class="ttname"><a href="group__terminus.html#gad202baf5c904d6991e13521b7c93fdc2">pn_terminus_t</a></div><div class="ttdeci">struct pn_terminus_t pn_terminus_t</div><div class="ttdoc">Encapsulates the endpoint state associated with an AMQP Terminus. </div><div class="ttdef"><b>Definition:</b> terminus.h:53</div></div>
 <div class="ttc" id="group__link_html_ga06c97ce7396973dca0d311567f25f95a"><div class="ttname"><a href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_recv</a></div><div class="ttdeci">ssize_t pn_link_recv(pn_link_t *receiver, char *bytes, size_t n)</div><div class="ttdoc">Receive message data for the current delivery on a link. </div></div>
 <div class="ttc" id="group__link_html_ga997c85388b9fb30151ea3b40b946e958"><div class="ttname"><a href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a></div><div class="ttdeci">pn_terminus_t * pn_link_target(pn_link_t *link)</div><div class="ttdoc">Access the locally defined target definition for a link. </div></div>
-<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:294</div></div>
-<div class="ttc" id="group__link_html_ga93e6b527743f433da2ff367c1b2c500a"><div class="ttname"><a href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a></div><div class="ttdeci">void * pn_link_get_context(pn_link_t *link)</div></div>
+<div class="ttc" id="group__session_html_ga38ccb93b8f5c2892adafce5d5f0fbcd9"><div class="ttname"><a href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a></div><div class="ttdeci">struct pn_session_t pn_session_t</div><div class="ttdoc">An AMQP Session object. </div><div class="ttdef"><b>Definition:</b> types.h:292</div></div>
+<div class="ttc" id="group__link_html_ga93e6b527743f433da2ff367c1b2c500a"><div class="ttname"><a href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a></div><div class="ttdeci">void * pn_link_get_context(pn_link_t *link)</div><div class="ttdoc">Deprecated - Use pn_link_attachments(). </div></div>
 <div class="ttc" id="group__link_html_ga677c416a6365cedd23b43043dff0b89f"><div class="ttname"><a href="group__link.html#ga677c416a6365cedd23b43043dff0b89f">pn_link_set_snd_settle_mode</a></div><div class="ttdeci">void pn_link_set_snd_settle_mode(pn_link_t *link, pn_snd_settle_mode_t mode)</div><div class="ttdoc">Set the local sender settle mode for a link. </div></div>
 <div class="ttc" id="terminus_8h_html"><div class="ttname"><a href="terminus_8h.html">terminus.h</a></div><div class="ttdoc">A source or target for messages. </div></div>
 <div class="ttc" id="group__link_html_ga5e314b3e07b48ebcffbac63f265fa69f"><div class="ttname"><a href="group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f">pn_receiver</a></div><div class="ttdeci">pn_link_t * pn_receiver(pn_session_t *session, const char *name)</div><div class="ttdoc">Construct a new receiver on a session. </div></div>
@@ -129,7 +129,7 @@ $(document).ready(function(){initNavTree('link_8h_source.html','');});
 <div class="ttc" id="condition_8h_html"><div class="ttname"><a href="condition_8h.html">condition.h</a></div><div class="ttdoc">An endpoint error state. </div></div>
 <div class="ttc" id="group__link_html_gad502b38bc184ad0bfaa86dede81f62c9"><div class="ttname"><a href="group__link.html#gad502b38bc184ad0bfaa86dede81f62c9">pn_link_state</a></div><div class="ttdeci">pn_state_t pn_link_state(pn_link_t *link)</div><div class="ttdoc">Get the endpoint state flags for a link. </div></div>
 <div class="ttc" id="group__link_html_ga92592155f2afcf6b9aabfb4fc64c140f"><div class="ttname"><a href="group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f">pn_link_remote_snd_settle_mode</a></div><div class="ttdeci">pn_snd_settle_mode_t pn_link_remote_snd_settle_mode(pn_link_t *link)</div><div class="ttdoc">Get the remote sender settle mode for a link. </div></div>
-<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:403</div></div>
+<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:401</div></div>
 <div class="ttc" id="group__link_html_gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0"><div class="ttname"><a href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0">PN_SND_SETTLED</a></div><div class="ttdoc">The sender will send all deliveries settled to the receiver. </div><div class="ttdef"><b>Definition:</b> link.h:477</div></div>
 <div class="ttc" id="group__link_html_gad7ad9bc5c9ea7e8a21cd4fa472d2c8df"><div class="ttname"><a href="group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df">pn_link_drain</a></div><div class="ttdeci">void pn_link_drain(pn_link_t *receiver, int credit)</div><div class="ttdoc">Grant credit for incoming deliveries on a receiver, and set drain mode to true. </div></div>
 <div class="ttc" id="group__link_html_ga378e4bb5a0519a75c3c151c15809dda5"><div class="ttname"><a href="group__link.html#ga378e4bb5a0519a75c3c151c15809dda5">pn_link_remote_rcv_settle_mode</a></div><div class="ttdeci">pn_rcv_settle_mode_t pn_link_remote_rcv_settle_mode(pn_link_t *link)</div><div class="ttdoc">Get the remote receiver settle mode for a link. </div></div>
@@ -144,12 +144,12 @@ $(document).ready(function(){initNavTree('link_8h_source.html','');});
 <div class="ttc" id="group__link_html_ga2421a9ddebba208338412dea365cf6ad"><div class="ttname"><a href="group__link.html#ga2421a9ddebba208338412dea365cf6ad">pn_link_set_max_message_size</a></div><div class="ttdeci">void pn_link_set_max_message_size(pn_link_t *link, uint64_t size)</div><div class="ttdoc">Unsettled API - Set the maximum message size for a link. </div></div>
 <div class="ttc" id="group__link_html_gac282341dacff892eba8e224eca5c5c52"><div class="ttname"><a href="group__link.html#gac282341dacff892eba8e224eca5c5c52">pn_link_max_message_size</a></div><div class="ttdeci">uint64_t pn_link_max_message_size(pn_link_t *link)</div><div class="ttdoc">Unsettled API - Get the maximum message size for a link. </div></div>
 <div class="ttc" id="group__link_html_gab6441a917c291e68984405057eb56ab8"><div class="ttname"><a href="group__link.html#gab6441a917c291e68984405057eb56ab8">pn_link_set_rcv_settle_mode</a></div><div class="ttdeci">void pn_link_set_rcv_settle_mode(pn_link_t *link, pn_rcv_settle_mode_t mode)</div><div class="ttdoc">Set the local receiver settle mode for a link. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__link_html_ga97dc5133125c9b7e4afbb1b76e6efe7b"><div class="ttname"><a href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a></div><div class="ttdeci">pn_condition_t * pn_link_remote_condition(pn_link_t *link)</div><div class="ttdoc">Get the remote condition associated with a link endpoint. </div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
 <div class="ttc" id="group__link_html_gaef3f2e4bca87f9adc70e90dce7cd42b2"><div class="ttname"><a href="group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2">pn_link_offered</a></div><div class="ttdeci">void pn_link_offered(pn_link_t *sender, int credit)</div><div class="ttdoc">Signal the availability of deliveries for a link. </div></div>
-<div class="ttc" id="group__link_html_gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1"><div class="ttname"><a href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">PN_SND_MIXED</a></div><div class="ttdoc">The sender may send a mixure of settled and unsettled deliveries. </div><div class="ttdef"><b>Definition:</b> link.h:479</div></div>
-<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:269</div></div>
+<div class="ttc" id="group__link_html_gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1"><div class="ttname"><a href="group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1">PN_SND_MIXED</a></div><div class="ttdoc">The sender may send a mixture of settled and unsettled deliveries. </div><div class="ttdef"><b>Definition:</b> link.h:479</div></div>
+<div class="ttc" id="group__connection_html_gaa83193a655e32bffc18624acc2c39233"><div class="ttname"><a href="group__connection.html#gaa83193a655e32bffc18624acc2c39233">pn_state_t</a></div><div class="ttdeci">int pn_state_t</div><div class="ttdoc">Holds the state flags for an AMQP endpoint. </div><div class="ttdef"><b>Definition:</b> types.h:267</div></div>
 <div class="ttc" id="group__link_html_gaeb417e6b7e99c76f61549f5ed5519395"><div class="ttname"><a href="group__link.html#gaeb417e6b7e99c76f61549f5ed5519395">pn_link_set_drain</a></div><div class="ttdeci">void pn_link_set_drain(pn_link_t *receiver, bool drain)</div><div class="ttdoc">Set the drain mode on a link. </div></div>
 <div class="ttc" id="group__link_html_ga7f1742528b32c3c9609b97a3ed449639"><div class="ttname"><a href="group__link.html#ga7f1742528b32c3c9609b97a3ed449639">pn_link_available</a></div><div class="ttdeci">int pn_link_available(pn_link_t *link)</div><div class="ttdoc">Get the available deliveries hint for a link. </div></div>
 <div class="ttc" id="group__link_html_ga4a821eaf6298b94522572fad73b8e2d1"><div class="ttname"><a href="group__link.html#ga4a821eaf6298b94522572fad73b8e2d1">pn_link_draining</a></div><div class="ttdeci">bool pn_link_draining(pn_link_t *receiver)</div><div class="ttdoc">Check if a link is currently draining. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/listener_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/listener_8h.html b/content/releases/qpid-proton-master/proton/c/api/listener_8h.html
index 3c8de3f..efee9e9 100755
--- a/content/releases/qpid-proton-master/proton/c/api/listener_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/listener_8h.html
@@ -112,9 +112,11 @@ Functions</h2></td></tr>
 <tr class="memitem:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">pn_listener_free</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
 <tr class="memdesc:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free a listener.  <a href="group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63">More...</a><br /></td></tr>
 <tr class="separator:gaf5769baf81fdfa80e5c4326dd4a9ab63"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gaaee3c3f3822484bc2e370406abf5b736"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *)</td></tr>
-<tr class="memdesc:gaaee3c3f3822484bc2e370406abf5b736"><td class="mdescLeft">&#160;</td><td class="mdescRight">Bind <code>connection</code> to a new transport accepted from <code>listener</code>.  <a href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">More...</a><br /></td></tr>
-<tr class="separator:gaaee3c3f3822484bc2e370406abf5b736"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga3719a4ab17b8de42fc6bfb262018d070"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">pn_listener_accept2</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:ga3719a4ab17b8de42fc6bfb262018d070"><td class="mdescLeft">&#160;</td><td class="mdescRight">Accept an incoming connection request using <code>transport</code> and <code>connection</code>, which can be configured before the call.  <a href="group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070">More...</a><br /></td></tr>
+<tr class="separator:ga3719a4ab17b8de42fc6bfb262018d070"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ga8a100386ab4a079ae6924aeaafc72eb9"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">pn_listener_accept</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
+<tr class="separator:ga8a100386ab4a079ae6924aeaafc72eb9"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaa49d0d11a9f46a75fbbbebf6def2d4b2"><td class="memItemLeft" align="right" valign="top">
 PNP_EXTERN <a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a> (<a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *l)</td></tr>
 <tr class="memdesc:gaa49d0d11a9f46a75fbbbebf6def2d4b2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the error condition for a listener. <br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/listener_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/listener_8h.js b/content/releases/qpid-proton-master/proton/c/api/listener_8h.js
index c8febad..d62ad37 100755
--- a/content/releases/qpid-proton-master/proton/c/api/listener_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/listener_8h.js
@@ -2,7 +2,8 @@ var listener_8h =
 [
     [ "pn_listener", "group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5", null ],
     [ "pn_listener_free", "group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63", null ],
-    [ "pn_listener_accept", "group__listener.html#gaaee3c3f3822484bc2e370406abf5b736", null ],
+    [ "pn_listener_accept2", "group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070", null ],
+    [ "pn_listener_accept", "group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9", null ],
     [ "pn_listener_condition", "group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2", null ],
     [ "pn_listener_attachments", "group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f", null ],
     [ "pn_listener_close", "group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104", null ],


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


[10/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/decoder_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/decoder_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/decoder_8hpp_source.html
index 7fb586f..505a801 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/decoder_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/decoder_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('decoder_8hpp_source.html','');});
 <div class="title">decoder.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="decoder_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CODEC_DECODER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CODEC_DECODER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contrib
 utor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&
 #160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the Licens
 e for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;../internal/data.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;../internal/type_traits.hpp&quot;</span></div><div class="line"><a name="l00
 027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;../types_fwd.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="common_8hpp.html">./common.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;utility&gt;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span
  class="lineno">   37</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>annotation_key;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">class </span>message_id;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">class </span>scalar;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">class </span>value;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">namespace </span>internal {</div><div class="line"><a name="l00045"></a><span c
 lass="lineno">   45</span>&#160;<span class="keyword">class </span>value_base;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;}</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">namespace </span>codec {</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html">   56</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a> : <span class="keyword">public</span> internal::data {</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00061"></a><span class="lineno"><a class="line" href="classproton_1_1co
 dec_1_1decoder.html#ac9222fed91a5066887b42f471de0be8a">   61</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1decoder.html#ac9222fed91a5066887b42f471de0be8a">decoder</a>(<span class="keyword">const</span> data&amp; d, <span class="keywordtype">bool</span> exact=<span class="keyword">false</span>) : data(d), exact_(exact) {}</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>(<span class="keyword">const</span> internal::value_base&amp;, <span class="keywordtype">bool</span> exact=<span class="keyword">false</span>);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_
 EXTERN <span class="keywordtype">void</span> decode(<span class="keyword">const</span> <span class="keywordtype">char</span>* buffer, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> decode(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> more();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    PN_CPP_EXTERN <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> next_type();</div><div cla
 ss="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">bool</span>&amp;);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint8_t&amp;);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int8_t&amp;);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(
 uint16_t&amp;);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int16_t&amp;);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint32_t&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int32_t&amp;);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">wchar_t</span>&amp;);</div><div class="line"><a name="l00
 099"></a><span class="lineno">   99</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint64_t&amp;);</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int64_t&amp;);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>&amp;);</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">float</span>&amp;);</div><div class="line"><a nam
 e="l00103"></a><span class="lineno">  103</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">double</span>&amp;);</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal32.html">decimal32</a>&amp;);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal64.html">decimal64</a>&amp;);</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">
 operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal128.html">decimal128</a>&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1uuid.html">uuid</a>&amp;);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(std::string&amp;);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1symbol.html">symbol</a>&amp;);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;    PN_CPP_EXTERN decoder&a
 mp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1binary.html">binary</a>&amp;);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1annotation__key.html">annotation_key</a>&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="cla
 ssproton_1_1scalar.html">scalar</a>&amp;);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(internal::value_base&amp;);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(null&amp;);</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a>&amp;);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><
 div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>&amp;);</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>sequence_ref { T&amp; ref; sequence_ref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>associative_ref { T&amp; ref; associative_ref(T&amp; r) : ref(r) {} };</div><div class="lin
 e"><a name="l00131"></a><span class="lineno">  131</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>pair_sequence_ref { T&amp; ref;  pair_sequence_ref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> sequence_ref&lt;T&gt; sequence(T&amp; x) { <span class="keywordflow">return</span> sequence_ref&lt;T&gt;(x); }</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> associative_ref&lt;T&gt; associative(T&amp; x) { <span class="keywordflow">return</span> associative_ref&lt;T&gt;(x); }</div><di
 v class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> pair_sequence_ref&lt;T&gt; pair_sequence(T&amp; x) { <span class="keywordflow">return</span> pair_sequence_ref&lt;T&gt;(x); }</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#ac6c6ddca9af56625b28bc7989b02f24b">  141</a></span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; decoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#ac6c6ddca9af56625b28bc7989b02f24b">operator&gt;&gt;</a>(sequence_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_
 1_1start">start</a> s;</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;        *<span class="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;        <span class="keywordflow">if</span> (s.is_described) next();</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;        r.ref.resize(s.size);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::iterator i = r.ref.begin(); i != r.ref.end(); ++i)</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;            *<span class="keyword">this</span> &gt;&gt; *i;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00149">
 </a><span class="lineno">  149</span>&#160;    }</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#a92c526a77d6aa412e17051a2cfeb7210">  152</a></span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; decoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#a92c526a77d6aa412e17051a2cfeb7210">operator&gt;&gt;</a>(associative_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;        <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> s;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;        *<span class
 ="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;        <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(<a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a4cafa5feda04184537b4d7d346e1e89b">MAP</a>, s.type);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;        r.ref.clear();</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;        <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; s.size/2; ++i) {</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename T::key_type&gt;::type k;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;            <span class="keyword">typename</span> remove_const&lt;type
 name T::mapped_type&gt;::type v;</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;            *<span class="keyword">this</span> &gt;&gt; k &gt;&gt; v;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;            r.ref[k] = v;</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;        }</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;    }</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00169"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#ad96e5571bbd7384096ca07a8a9368ffc">  169</a></span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; d
 ecoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#ad96e5571bbd7384096ca07a8a9368ffc">operator&gt;&gt;</a>(pair_sequence_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;        <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> s;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;        *<span class="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;        <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(<a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a4cafa5feda04184537b4d7d346e1e89b">MAP</a>, s.type);</div><div class="line"><a name="l00174"></a><
 span class="lineno">  174</span>&#160;        r.ref.clear();</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;        <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; s.size/2; ++i) {</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;            <span class="keyword">typedef</span> <span class="keyword">typename</span> T::value_type value_type;</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename value_type::first_type&gt;::type k;</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename value_type::second_type&gt;::type v;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;            *<span class="keyword">this</span> &gt;&gt; k &gt;&gt; v
 ;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;            r.ref.push_back(value_type(k, v));</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;        }</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;    }</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;    <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> pre_get();</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;    <span class="keyword">template</sp
 an> &lt;<span class="keyword">class</span> T, <span class="keyword">class</span> U&gt; decoder&amp; extract(T&amp; x, U (*<span class="keyword">get</span>)(pn_data_t*));</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;    <span class="keywordtype">bool</span> exact_;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1message.html">message</a>;</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;};</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">class</span> T&gt; T <span class="keyword">get</span>(<a class="code" href
 ="classproton_1_1codec_1_1decoder.html">decoder</a>&amp; d) {</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;    <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(internal::type_id_of&lt;T&gt;::value, d.next_type());</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;    T x;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;    d &gt;&gt; x;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;    <span class="keywordflow">return</span> x;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;}</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">typename</span
 > internal::enable_if&lt;internal::is_unknown_integer&lt;T&gt;::value, <a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>&amp;&gt;::type</div><div class="line"><a name="l00206"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#a7efc9868b69ee772a81b1f6f63ddcb36">  206</a></span>&#160;<a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>&amp; d, T&amp; i)  {</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;    <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;    <span class="keyword">typename</span> integer_type&lt;sizeof(T), is_signed&lt;T&gt;::value&gt;::type v;</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;    d &gt;&gt; v;                     <span class="commen
 t">// Extract as a known integer type</span></div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;    i = v;                      <span class="comment">// C++ conversion to the target type.</span></div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;    <span class="keywordflow">return</span> d;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;}</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;} <span class="comment">// codec</span></div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;<span class="preprocessor">#endif // PROTON_CODEC_DECODER
 _HPP</span></div><div class="ttc" id="classproton_1_1scalar_html"><div class="ttname"><a href="classproton_1_1scalar.html">proton::scalar</a></div><div class="ttdoc">A holder for an instance of any scalar AMQP type. </div><div class="ttdef"><b>Definition:</b> scalar.hpp:35</div></div>
+<a href="decoder_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CODEC_DECODER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CODEC_DECODER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contrib
 utor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&
 #160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the Licens
 e for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;../internal/data.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;../internal/type_traits.hpp&quot;</span></div><div class="line"><a name="l00
 027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;../types_fwd.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="common_8hpp.html">./common.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &lt;utility&gt;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span
  class="lineno">   37</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>annotation_key;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">class </span>message_id;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">class </span>scalar;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">class </span>value;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">namespace </span>internal {</div><div class="line"><a name="l00045"></a><span c
 lass="lineno">   45</span>&#160;<span class="keyword">class </span>value_base;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;}</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">namespace </span>codec {</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html">   56</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a> : <span class="keyword">public</span> internal::data {</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00061"></a><span class="lineno"><a class="line" href="classproton_1_1co
 dec_1_1decoder.html#ac9222fed91a5066887b42f471de0be8a">   61</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1decoder.html#ac9222fed91a5066887b42f471de0be8a">decoder</a>(<span class="keyword">const</span> data&amp; d, <span class="keywordtype">bool</span> exact=<span class="keyword">false</span>) : data(d), exact_(exact) {}</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keyword">explicit</span> <a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>(<span class="keyword">const</span> internal::value_base&amp;, <span class="keywordtype">bool</span> exact=<span class="keyword">false</span>);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_
 EXTERN <span class="keywordtype">void</span> decode(<span class="keyword">const</span> <span class="keywordtype">char</span>* buffer, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> decode(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> more();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    PN_CPP_EXTERN <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> next_type();</div><div cla
 ss="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">bool</span>&amp;);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint8_t&amp;);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int8_t&amp;);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(
 uint16_t&amp;);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int16_t&amp;);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint32_t&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int32_t&amp;);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">wchar_t</span>&amp;);</div><div class="line"><a name="l00
 099"></a><span class="lineno">   99</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(uint64_t&amp;);</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(int64_t&amp;);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>&amp;);</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">float</span>&amp;);</div><div class="line"><a nam
 e="l00103"></a><span class="lineno">  103</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keywordtype">double</span>&amp;);</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal32.html">decimal32</a>&amp;);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal64.html">decimal64</a>&amp;);</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">
 operator&gt;&gt;</a>(<a class="code" href="classproton_1_1decimal128.html">decimal128</a>&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1uuid.html">uuid</a>&amp;);</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(std::string&amp;);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1symbol.html">symbol</a>&amp;);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;    PN_CPP_EXTERN decoder&a
 mp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1binary.html">binary</a>&amp;);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1annotation__key.html">annotation_key</a>&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="cla
 ssproton_1_1scalar.html">scalar</a>&amp;);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(internal::value_base&amp;);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1null.html">null</a>&amp;);</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a>&amp;);</div><div class="line"><a name="l00123
 "></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;    PN_CPP_EXTERN decoder&amp; <a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<span class="keyword">const</span> <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">finish</a>&amp;);</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>sequence_ref { T&amp; ref; sequence_ref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>associative_ref { T&amp; ref; associati
 ve_ref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">struct </span>pair_sequence_ref { T&amp; ref;  pair_sequence_ref(T&amp; r) : ref(r) {} };</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> sequence_ref&lt;T&gt; sequence(T&amp; x) { <span class="keywordflow">return</span> sequence_ref&lt;T&gt;(x); }</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> associative_ref&lt;T&gt; associative(T&amp; x) { <span class="keywordflow">r
 eturn</span> associative_ref&lt;T&gt;(x); }</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">static</span> pair_sequence_ref&lt;T&gt; pair_sequence(T&amp; x) { <span class="keywordflow">return</span> pair_sequence_ref&lt;T&gt;(x); }</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#ac6c6ddca9af56625b28bc7989b02f24b">  141</a></span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; decoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#ac6c6ddca9af56625b28bc7989b02f24b">operator&gt;&gt;</a>(sequence_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;        <a class="code" href="
 namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> s;</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;        *<span class="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;        <span class="keywordflow">if</span> (s.is_described) next();</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;        r.ref.resize(s.size);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;        <span class="keywordflow">for</span> (<span class="keyword">typename</span> T::iterator i = r.ref.begin(); i != r.ref.end(); ++i)</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;            *<span class="keyword">this</span> &gt;&gt; *i;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">t
 his</span>;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;    }</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#a92c526a77d6aa412e17051a2cfeb7210">  152</a></span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; decoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#a92c526a77d6aa412e17051a2cfeb7210">operator&gt;&gt;</a>(associative_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;        <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> s;</div><div class="line"><a name="l00155"></a><span c
 lass="lineno">  155</span>&#160;        *<span class="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;        <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(<a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a4cafa5feda04184537b4d7d346e1e89b">MAP</a>, s.type);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;        r.ref.clear();</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;        <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; s.size/2; ++i) {</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename T::key_type&gt;::type k;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;            <span 
 class="keyword">typename</span> remove_const&lt;typename T::mapped_type&gt;::type v;</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;            *<span class="keyword">this</span> &gt;&gt; k &gt;&gt; v;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;            r.ref[k] = v;</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;        }</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;    }</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00169"></a><span class="lineno"><a class="line" href="classproton_1_1codec_1_1decoder.html#ad96e5571bbd7384096ca07a8a9368ffc">  169</a></span>&#160;    <span class="keyword">template</
 span> &lt;<span class="keyword">class</span> T&gt; decoder&amp; <a class="code" href="classproton_1_1codec_1_1decoder.html#ad96e5571bbd7384096ca07a8a9368ffc">operator&gt;&gt;</a>(pair_sequence_ref&lt;T&gt; r)  {</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;        <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;        <a class="code" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">start</a> s;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;        *<span class="keyword">this</span> &gt;&gt; s;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;        <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(<a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9a4cafa5feda04184537b4d7d346e1e89b">MAP</a>, s.
 type);</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;        r.ref.clear();</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;        <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; s.size/2; ++i) {</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;            <span class="keyword">typedef</span> <span class="keyword">typename</span> T::value_type value_type;</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename value_type::first_type&gt;::type k;</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;            <span class="keyword">typename</span> remove_const&lt;typename value_type::second_type&gt;::type v;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;            *<sp
 an class="keyword">this</span> &gt;&gt; k &gt;&gt; v;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;            r.ref.push_back(value_type(k, v));</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;        }</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;        <span class="keywordflow">return</span> *<span class="keyword">this</span>;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;    }</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;    <a class="code" href="namespaceproton.html#a83c2656d467d69eb49725c18f5aa13a9">type_id</a> pre_get();</div><div class="line"><a name="l00187"></a><span class="lineno">  18
 7</span>&#160;    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T, <span class="keyword">class</span> U&gt; decoder&amp; extract(T&amp; x, U (*<span class="keyword">get</span>)(pn_data_t*));</div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;    <span class="keywordtype">bool</span> exact_;</div><div class="line"><a name="l00189"></a><span class="lineno">  189</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1message.html">message</a>;</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;};</div><div class="line"><a name="l00192"></a><span class="lineno">  192</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;<span class="keyword">template</span>&lt;<span class="keyword">class</span> T&gt; T <
 span class="keyword">get</span>(<a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>&amp; d) {</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;    <a class="code" href="namespaceproton.html#aa77887032372174b09ee779f5df12056">assert_type_equal</a>(internal::type_id_of&lt;T&gt;::value, d.next_type());</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;    T x;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;    d &gt;&gt; x;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;    <span class="keywordflow">return</span> x;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;}</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">cla
 ss</span> T&gt; <span class="keyword">typename</span> internal::enable_if&lt;internal::is_unknown_integer&lt;T&gt;::value, <a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>&amp;&gt;::type</div><div class="line"><a name="l00206"></a><span class="lineno"><a class="line" href="namespaceproton_1_1codec.html#a7efc9868b69ee772a81b1f6f63ddcb36">  206</a></span>&#160;<a class="code" href="namespaceproton.html#a6bf02b4db50d17a060e281c8317a11d0">operator&gt;&gt;</a>(<a class="code" href="classproton_1_1codec_1_1decoder.html">decoder</a>&amp; d, T&amp; i)  {</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;    <span class="keyword">using namespace </span>internal;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;    <span class="keyword">typename</span> integer_type&lt;sizeof(T), is_signed&lt;T&gt;::value&gt;::type v;</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;    d
  &gt;&gt; v;                     <span class="comment">// Extract as a known integer type</span></div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;    i = v;                      <span class="comment">// C++ conversion to the target type.</span></div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;    <span class="keywordflow">return</span> d;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;}</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;} <span class="comment">// codec</span></div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;<span
  class="preprocessor">#endif // PROTON_CODEC_DECODER_HPP</span></div><div class="ttc" id="classproton_1_1scalar_html"><div class="ttname"><a href="classproton_1_1scalar.html">proton::scalar</a></div><div class="ttdoc">A holder for an instance of any scalar AMQP type. </div><div class="ttdef"><b>Definition:</b> scalar.hpp:37</div></div>
 <div class="ttc" id="classproton_1_1message_html"><div class="ttname"><a href="classproton_1_1message.html">proton::message</a></div><div class="ttdoc">An AMQP message. </div><div class="ttdef"><b>Definition:</b> message.hpp:50</div></div>
 <div class="ttc" id="namespaceproton_1_1codec_html_structproton_1_1codec_1_1start"><div class="ttname"><a href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start">proton::codec::start</a></div><div class="ttdoc">Unsettled API - Start encoding a complex type. </div><div class="ttdef"><b>Definition:</b> common.hpp:34</div></div>
 <div class="ttc" id="classproton_1_1annotation__key_html"><div class="ttname"><a href="classproton_1_1annotation__key.html">proton::annotation_key</a></div><div class="ttdoc">A key for use with AMQP annotation maps. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:38</div></div>
@@ -115,6 +115,7 @@ $(document).ready(function(){initNavTree('decoder_8hpp_source.html','');});
 <div class="ttc" id="namespaceproton_1_1codec_html_structproton_1_1codec_1_1finish"><div class="ttname"><a href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1finish">proton::codec::finish</a></div><div class="ttdoc">Unsettled API - Finish inserting or extracting a complex type. </div><div class="ttdef"><b>Definition:</b> common.hpp:57</div></div>
 <div class="ttc" id="classproton_1_1codec_1_1decoder_html_ac9222fed91a5066887b42f471de0be8a"><div class="ttname"><a href="classproton_1_1codec_1_1decoder.html#ac9222fed91a5066887b42f471de0be8a">proton::codec::decoder::decoder</a></div><div class="ttdeci">decoder(const data &amp;d, bool exact=false)</div><div class="ttdoc">Wrap a Proton C data object. </div><div class="ttdef"><b>Definition:</b> decoder.hpp:61</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
+<div class="ttc" id="classproton_1_1null_html"><div class="ttname"><a href="classproton_1_1null.html">proton::null</a></div><div class="ttdoc">The type of the AMQP null value. </div><div class="ttdef"><b>Definition:</b> null.hpp:38</div></div>
 <div class="ttc" id="classproton_1_1codec_1_1decoder_html"><div class="ttname"><a href="classproton_1_1codec_1_1decoder.html">proton::codec::decoder</a></div><div class="ttdoc">Unsettled API - A stream-like decoder from AMQP bytes to C++ values. </div><div class="ttdef"><b>Definition:</b> decoder.hpp:56</div></div>
 <div class="ttc" id="classproton_1_1message__id_html"><div class="ttname"><a href="classproton_1_1message__id.html">proton::message_id</a></div><div class="ttdoc">An AMQP message ID. </div><div class="ttdef"><b>Definition:</b> message_id.hpp:47</div></div>
 </div><!-- fragment --></div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp.html b/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp.html
index e6f94eb..3fcf109 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp.html
@@ -97,9 +97,10 @@ $(document).ready(function(){initNavTree('default__container_8hpp.html','');});
 </div><!--header-->
 <div class="contents">
 
-<p><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>.  
+<p><b>Deprecated</b> - Use the API in <code><a class="el" href="container_8hpp.html" title="A top-level container of connections, sessions, and links. ">container.hpp</a></code>.  
 <a href="#details">More...</a></p>
-
+<div class="textblock"><code>#include &quot;./internal/export.hpp&quot;</code><br />
+</div>
 <p><a href="default__container_8hpp_source.html">Go to the source code of this file.</a></p>
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="namespaces"></a>
@@ -116,7 +117,7 @@ typedef class container&#160;</td><td class="memItemRight" valign="bottom"><a cl
 <tr class="separator:a75c08d991f463e6a7bad0cff8736bc8a"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
-<div class="textblock"><p><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>. </p>
+<div class="textblock"><p><b>Deprecated</b> - Use the API in <code><a class="el" href="container_8hpp.html" title="A top-level container of connections, sessions, and links. ">container.hpp</a></code>. </p>
 </div></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp_source.html
index 388a8b5..4580b92 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/default__container_8hpp_source.html
@@ -93,8 +93,8 @@ $(document).ready(function(){initNavTree('default__container_8hpp_source.html','
 <div class="title">default_container.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="default__container_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"
 > * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="li
 neno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or impli
 ed.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&
 #160;</div><div class="line"><a name="l00031"></a><span class="lineno"><a class="line" href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">   31</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a> <a class="code" href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">default_container</a>;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#endif // PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a>
 </div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
-<div class="ttc" id="namespaceproton_html_a75c08d991f463e6a7bad0cff8736bc8a"><div class="ttname"><a href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">proton::default_container</a></div><div class="ttdeci">class container default_container</div><div class="ttdoc">Deprecated - Use proton::container. </div><div class="ttdef"><b>Definition:</b> default_container.hpp:31</div></div>
+<a href="default__container_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"
 > * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="li
 neno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or impli
 ed.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div cla
 ss="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno"><a class="line" href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">   33</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a> PN_CPP_DEPRECATED(&quot;Use &#39;<a class="code" href="namespaceproton.html">proton</a>::<a class="code" href="classproton_1_1container.html">container</a>&#39;&quot;) <a class="code" href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">default_container</a>;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;} <span
  class="comment">// proton</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#endif // PROTON_DEFAULT_CONTAINER_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
+<div class="ttc" id="namespaceproton_html_a75c08d991f463e6a7bad0cff8736bc8a"><div class="ttname"><a href="namespaceproton.html#a75c08d991f463e6a7bad0cff8736bc8a">proton::default_container</a></div><div class="ttdeci">class container default_container</div><div class="ttdoc">Deprecated - Use proton::container. </div><div class="ttdef"><b>Definition:</b> default_container.hpp:33</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/deprecated.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/deprecated.html b/content/releases/qpid-proton-master/proton/cpp/api/deprecated.html
new file mode 100755
index 0000000..ac2a345
--- /dev/null
+++ b/content/releases/qpid-proton-master/proton/cpp/api/deprecated.html
@@ -0,0 +1,111 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
+<html xmlns="http://www.w3.org/1999/xhtml">
+<head>
+<meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
+<meta http-equiv="X-UA-Compatible" content="IE=9"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
+<title>Qpid Proton C++ API: Deprecated List</title>
+<link href="tabs.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="jquery.js"></script>
+<script type="text/javascript" src="dynsections.js"></script>
+<link href="navtree.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="resize.js"></script>
+<script type="text/javascript" src="navtreedata.js"></script>
+<script type="text/javascript" src="navtree.js"></script>
+<script type="text/javascript">
+  $(document).ready(initResizable);
+</script>
+<link href="search/search.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="search/searchdata.js"></script>
+<script type="text/javascript" src="search/search.js"></script>
+<script type="text/javascript">
+  $(document).ready(function() { init_search(); });
+</script>
+<link href="doxygen.css" rel="stylesheet" type="text/css" />
+</head>
+<body>
+<div id="top"><!-- do not remove this div, it is closed by doxygen! -->
+<div id="titlearea">
+<table cellspacing="0" cellpadding="0">
+ <tbody>
+ <tr style="height: 56px;">
+  <td id="projectalign" style="padding-left: 0.5em;">
+   <div id="projectname">Qpid Proton C++ API
+   &#160;<span id="projectnumber">master</span>
+   </div>
+  </td>
+   <td>        <div id="MSearchBox" class="MSearchBoxInactive">
+        <span class="left">
+          <img id="MSearchSelect" src="search/mag_sel.png"
+               onmouseover="return searchBox.OnSearchSelectShow()"
+               onmouseout="return searchBox.OnSearchSelectHide()"
+               alt=""/>
+          <input type="text" id="MSearchField" value="Search" accesskey="S"
+               onfocus="searchBox.OnSearchFieldFocus(true)" 
+               onblur="searchBox.OnSearchFieldFocus(false)" 
+               onkeyup="searchBox.OnSearchFieldChange(event)"/>
+          </span><span class="right">
+            <a id="MSearchClose" href="javascript:searchBox.CloseResultsWindow()"><img id="MSearchCloseImg" border="0" src="search/close.png" alt=""/></a>
+          </span>
+        </div>
+</td>
+ </tr>
+ </tbody>
+</table>
+</div>
+<!-- end header part -->
+<!-- Generated by Doxygen 1.8.13 -->
+<script type="text/javascript">
+var searchBox = new SearchBox("searchBox", "search",false,'Search');
+</script>
+</div><!-- top -->
+<div id="side-nav" class="ui-resizable side-nav-resizable">
+  <div id="nav-tree">
+    <div id="nav-tree-contents">
+      <div id="nav-sync" class="sync"></div>
+    </div>
+  </div>
+  <div id="splitbar" style="-moz-user-select:none;" 
+       class="ui-resizable-handle">
+  </div>
+</div>
+<script type="text/javascript">
+$(document).ready(function(){initNavTree('deprecated.html','');});
+</script>
+<div id="doc-content">
+<!-- window showing the filter options -->
+<div id="MSearchSelectWindow"
+     onmouseover="return searchBox.OnSearchSelectShow()"
+     onmouseout="return searchBox.OnSearchSelectHide()"
+     onkeydown="return searchBox.OnSearchSelectKey(event)">
+</div>
+
+<!-- iframe showing the search results (closed by default) -->
+<div id="MSearchResultsWindow">
+<iframe src="javascript:void(0)" frameborder="0" 
+        name="MSearchResults" id="MSearchResults">
+</iframe>
+</div>
+
+<div class="header">
+  <div class="headertitle">
+<div class="title">Deprecated List </div>  </div>
+</div><!--header-->
+<div class="contents">
+<div class="textblock"><dl class="reflist">
+<dt><a class="anchor" id="_deprecated000001"></a>Member <a class="el" href="classproton_1_1receiver__options.html#af313abfa8d5b19e4b61c779907eb9980">receiver_options::auto_settle</a>  (bool)</dt>
+<dd>not applicable to receiver, only to sender </dd>
+</dl>
+</div></div><!-- contents -->
+</div><!-- doc-content -->
+<!-- start footer part -->
+<div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
+  <ul>
+    <li class="footer">Generated by
+    <a href="http://www.doxygen.org/index.html">
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
+  </ul>
+</div>
+</body>
+</html>


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


[20/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/broker_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/broker_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/broker_8cpp-example.html
index 9d11304..85378d7 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/broker_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/broker_8cpp-example.html
@@ -93,8 +93,8 @@ $(document).ready(function(){initNavTree('broker_8cpp-example.html','');});
 <div class="title">broker.cpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<p>A broker using the <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>. You can use this to run other examples that reqiure an intermediary, or you can use any AMQP 1.0 broker. This broker creates queues automatically when a client tries to send or subscribe.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="co
 de" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="error__condition_8hpp.html">proton/error_condition.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="function_8hpp.html">proton/function.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listen__handler_8hpp.html">proton/listen_handler.hpp</a>&gt;</span></div><div class="line"><span class="p
 reprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender__options_8hpp.html">proton/sender_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="source__options_8hpp.html">proton/source_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="target_8hpp.html">proton/target.hpp</a>&gt;</span
 ></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="target__options_8hpp.html">proton/target_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8hpp.html">proton/transport.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;deque&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"></div><div class="line"><span class="preprocesso
 r">#if PN_CPP_SUPPORTS_THREADS</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line"><span class="preprocessor">#endif</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="comment">// This is a simplified model for a message broker, that only allows for messages to go to a</span></div><div class="line"><span class="comment">// single receiver.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// This broker is multithread safe and if compiled with C++11 with a multithreaded Proton</span></div><div class="line"><span class="comment">// binding library will use as many threads as there are thread resources available (usually</span></div><div class="line"><span class="comment">// cores)</span></div><div class="line"><span class="comment">//</spa
 n></div><div class="line"><span class="comment">// Queues are only created and never destroyed</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Broker Entities (that need to be individually serialised)</span></div><div class="line"><span class="comment">// QueueManager - Creates new queues, finds queues</span></div><div class="line"><span class="comment">// Queue        - Queues msgs, records subscribers, sends msgs to subscribers</span></div><div class="line"><span class="comment">// Connection   - Receives Messages from network, sends messages to network.</span></div><div class="line"></div><div class="line"><span class="comment">// Work</span></div><div class="line"><span class="comment">// FindQueue(queueName, connection) - From a Connection to the QueueManager</span></div><div class="line"><span class="comment">//     This will create the queue if it doesn&#39;t already exist and send a BoundQueue</span></div><div cla
 ss="line"><span class="comment">//     message back to the connection.</span></div><div class="line"><span class="comment">// BoundQueue(queue) - From the QueueManager to a Connection</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// QueueMsg(msg)        - From a Connection (receiver) to a Queue</span></div><div class="line"><span class="comment">// Subscribe(sender)    - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">// Flow(sender, credit) - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">// Unsubscribe(sender)  - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// SendMsg(msg)   - From a Queue to a Connection (sender)</span></div><div class="line"><span class="comment">// Unsubscribed() - From a Queue to a Connection (sender)</span></div><div 
 class="line"></div><div class="line"></div><div class="line"><span class="comment">// Simple debug output</span></div><div class="line"><span class="keywordtype">bool</span> verbose;</div><div class="line"><span class="preprocessor">#define DOUT(x) do {if (verbose) {x};} while (false)</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>Queue;</div><div class="line"><span class="keyword">class </span>Sender;</div><div class="line"></div><div class="line"><span class="keyword">typedef</span> std::map&lt;proton::sender, Sender*&gt; senders;</div><div class="line"></div><div class="line"><span class="keyword">class </span>Sender : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">friend</span> <span class="keyword">class </span>connection_handler;</div><div class="line"></div><div class="line">    <a name=
 "_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line">    senders&amp; senders_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>&amp; work_queue_;</div><div class="line">    std::string queue_name_;</div><div class="line">    Queue* queue_;</div><div class="line">    <span class="keywordtype">int</span> pending_credit_;</div><div class="line"></div><div class="line">    <span class="comment">// Messaging handlers</span></div><div class="line">    <span class="keywordtype">void</span> <a name="a3"></a><a class="code" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE;</div><div class="line">    <span class="keywordtype">void</span> <a name="a4"></a><a class="code" href="classproton_1_1messaging__handler.html#a7942b98699b
 d21e827041626ee1b5c84">on_sender_close</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE;</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Sender(<a class="code" href="classproton_1_1sender.html">proton::sender</a> s, senders&amp; ss) :</div><div class="line">        sender_(s), senders_(ss), work_queue_(s.work_queue()), queue_(0), pending_credit_(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(<a name="_a5"></a><a class="code" href="classproton_1_1work.html">proton::work</a> f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a name="a6"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line"></div><div class="line">    <span class="keywordt
 ype">void</span> boundQueue(Queue* q, std::string qn);</div><div class="line">    <span class="keywordtype">void</span> sendMsg(<a name="_a7"></a><a class="code" href="classproton_1_1message.html">proton::message</a> m) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; sending\n&quot;</span>;);</div><div class="line">        sender_.<a name="a8"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> unsubscribed() {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; deleting\n&quot;</span>;);</div><div class="line">        <span class="keyword">delet
 e</span> <span class="keyword">this</span>;</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// Queue - round robin subscriptions</span></div><div class="line"><span class="keyword">class </span>Queue {</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> work_queue_;</div><div class="line">    <span class="keyword">const</span> std::string name_;</div><div class="line">    std::deque&lt;proton::message&gt; messages_;</div><div class="line">    <span class="keyword">typedef</span> std::map&lt;Sender*, int&gt; subscriptions; <span class="comment">// With credit</span></div><div class="line">    subscriptions subscriptions_;</div><div class="line">    subscriptions::iterator current_;</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> tryToSend() {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringl
 iteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; tryToSend: &quot;</span> &lt;&lt; subscriptions_.size(););</div><div class="line">        <span class="comment">// Starting at current_, send messages to subscriptions with credit:</span></div><div class="line">        <span class="comment">// After each send try to find another subscription; Wrap around;</span></div><div class="line">        <span class="comment">// Finish when we run out of messages or credit.</span></div><div class="line">        <span class="keywordtype">size_t</span> outOfCredit = 0;</div><div class="line">        <span class="keywordflow">while</span> (!messages_.empty() &amp;&amp; outOfCredit&lt;subscriptions_.size()) {</div><div class="line">            <span class="comment">// If we got the end (or haven&#39;t started yet) start at the beginning</span></div><div class="line">            <span class="keywordflow">if</span> (current_==s
 ubscriptions_.end()) {</div><div class="line">                current_=subscriptions_.begin();</div><div class="line">            }</div><div class="line">            <span class="comment">// If we have credit send the message</span></div><div class="line">            DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; current_-&gt;second &lt;&lt; <span class="stringliteral">&quot;) &quot;</span>;);</div><div class="line">            <span class="keywordflow">if</span> (current_-&gt;second&gt;0) {</div><div class="line">                DOUT(std::cerr &lt;&lt; current_-&gt;first &lt;&lt; <span class="stringliteral">&quot; &quot;</span>;);</div><div class="line">                <a name="a9"></a><a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(current_-&gt;first, &amp;Sender::sendMsg, current_-&gt;first, messages_.front());</div><div class="line">                messages_.pop_front();</div><div class="
 line">                --current_-&gt;second;</div><div class="line">                ++current_;</div><div class="line">            } <span class="keywordflow">else</span> {</div><div class="line">                ++outOfCredit;</div><div class="line">            }</div><div class="line">        }</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">    }</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Queue(<a name="_a10"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; c, <span class="keyword">const</span> std::string&amp; n) :</div><div class="line">        work_queue_(c), name_(n), current_(subscriptions_.end())</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(<a class="code" href="classproton_1_1work.html">proton::work</a> f) {</div><
 div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> queueMsg(<a class="code" href="classproton_1_1message.html">proton::message</a> m) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) queueMsg\n&quot;</span>;);</div><div class="line">        messages_.push_back(m);</div><div class="line">        tryToSend();</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> flow(Sender* s, <span class="keywordtype">int</span> c) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span cla
 ss="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) flow: &quot;</span> &lt;&lt; c &lt;&lt; <span class="stringliteral">&quot; to &quot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        subscriptions_[s] = c;</div><div class="line">        tryToSend();</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> subscribe(Sender* s) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) subscribe Sender: &quot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">     
    subscriptions_[s] = 0;</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> unsubscribe(Sender* s) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) unsubscribe Sender: &quot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        <span class="comment">// If we&#39;re about to erase the current subscription move on</span></div><div class="line">        <span class="keywordflow">if</span> (current_ != subscriptions_.end() &amp;&amp; current_-&gt;first==s) ++current_;</div><div class="line">        subscriptions_.erase(s);</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(s, &amp;S
 ender::unsubscribed, s);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// We have credit to send a message.</span></div><div class="line"><span class="keywordtype">void</span> Sender::on_sendable(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) {</div><div class="line">    <span class="keywordflow">if</span> (queue_) {</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(queue_, &amp;Queue::flow, queue_, <span class="keyword">this</span>, sender.<a name="a11"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>());</div><div class="line">    } <span class="keywordflow">else</span> {</div><div class="line">        pending_credit_ = sender.<a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();</div><div class="l
 ine">    }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> Sender::on_sender_close(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) {</div><div class="line">    <span class="keywordflow">if</span> (queue_) {</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(queue_, &amp;Queue::unsubscribe, queue_, <span class="keyword">this</span>);</div><div class="line">    } <span class="keywordflow">else</span> {</div><div class="line">        <span class="comment">// TODO: Is it possible to be closed before we get the queue allocated?</span></div><div class="line">        <span class="comment">// If so, we should have a way to mark the sender deleted, so we can delete</span></div><div class="line">        <span class="comment">// on queue binding</span></div><div class="line">    }</div><div class="line">    senders_.
 erase(sender);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> Sender::boundQueue(Queue* q, std::string qn) {</div><div class="line">    DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; bound to Queue: &quot;</span> &lt;&lt; q &lt;&lt;<span class="stringliteral">&quot;(&quot;</span> &lt;&lt; qn &lt;&lt; <span class="stringliteral">&quot;)\n&quot;</span>;);</div><div class="line">    queue_ = q;</div><div class="line">    queue_name_ = qn;</div><div class="line"></div><div class="line">    <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(q, &amp;Queue::subscribe, q, <span class="keyword">this</span>);</div><div class="line">    sender_.<a name="a12"></a><a class="code" href="classproton_1_1sender.html#a9e8555112049fc2b4945120b3c45f8ab">open</a>(<a nam
 e="_a13"></a><a class="code" href="classproton_1_1sender__options.html">proton::sender_options</a>()</div><div class="line">        .source((<a name="_a14"></a><a class="code" href="classproton_1_1source__options.html">proton::source_options</a>().address(queue_name_)))</div><div class="line">        .handler(*<span class="keyword">this</span>));</div><div class="line">    <span class="keywordflow">if</span> (pending_credit_&gt;0) {</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(queue_, &amp;Queue::flow, queue_, <span class="keyword">this</span>, pending_credit_);</div><div class="line">    }</div><div class="line">    std::cout &lt;&lt; <span class="stringliteral">&quot;sending from &quot;</span> &lt;&lt; queue_name_ &lt;&lt; std::endl;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">class </span>Receiver : <span class="keyword">public</span> <a clas
 s="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">friend</span> <span class="keyword">class </span>connection_handler;</div><div class="line"></div><div class="line">    <a name="_a15"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver_;</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>&amp; work_queue_;</div><div class="line">    Queue* queue_;</div><div class="line">    std::deque&lt;proton::message&gt; messages_;</div><div class="line"></div><div class="line">    <span class="comment">// A message is received.</span></div><div class="line">    <span class="keywordtype">void</span> on_message(<a name="_a16"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m) OVERRIDE {</div><div class="line">       
  messages_.push_back(m);</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (queue_) {</div><div class="line">            queueMsgs();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> queueMsgs() {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Receiver: &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; queueing &quot;</span> &lt;&lt; messages_.size() &lt;&lt; <span class="stringliteral">&quot; msgs to: &quot;</span> &lt;&lt; queue_ &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        <span class="keywordflow">while</span> (!messages_.empty()) {</div><div class="line">            <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(queue_, &amp;Queue::queueMsg, q
 ueue_, messages_.front());</div><div class="line">            messages_.pop_front();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Receiver(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> r) :</div><div class="line">        receiver_(r), work_queue_(r.work_queue()), queue_(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(<a class="code" href="classproton_1_1work.html">proton::work</a> f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> boundQueue(Queue* q, std::string qn) {</div><div class="line">        DOU
 T(std::cerr &lt;&lt; <span class="stringliteral">&quot;Receiver: &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; bound to Queue: &quot;</span> &lt;&lt; q &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; qn &lt;&lt; <span class="stringliteral">&quot;)\n&quot;</span>;);</div><div class="line">        queue_ = q;</div><div class="line">        receiver_.<a name="a17"></a><a class="code" href="classproton_1_1receiver.html#a9e8555112049fc2b4945120b3c45f8ab">open</a>(<a name="_a18"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>()</div><div class="line">            .source((<a class="code" href="classproton_1_1source__options.html">proton::source_options</a>().address(qn)))</div><div class="line">            .handler(*<span class="keyword">this</span>));</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;receiving to &quot;</span> &lt;&lt; q
 n &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        queueMsgs();</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>QueueManager {</div><div class="line">    <a class="code" href="classproton_1_1container.html">proton::container</a>&amp; container_;</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> work_queue_;</div><div class="line">    <span class="keyword">typedef</span> std::map&lt;std::string, Queue*&gt; queues;</div><div class="line">    queues queues_;</div><div class="line">    <span class="keywordtype">int</span> next_id_; <span class="comment">// Use to generate unique queue IDs.</span></div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    QueueManager(<a class="code" href="classproton_1_1container.html">proton::container</a>&amp; c) :</div><div class="l
 ine">        container_(c), work_queue_(c), next_id_(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(<a class="code" href="classproton_1_1work.html">proton::work</a> f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt;</div><div class="line">    <span class="keywordtype">void</span> findQueue(T&amp; connection, std::string&amp; qn) {</div><div class="line">        <span class="keywordflow">if</span> (qn.empty()) {</div><div class="line">            <span class="comment">// Dynamic queue creation</span></div><div class="line">            std::ostringstream os;</div><div class="line">            os &lt;&lt; <span c
 lass="stringliteral">&quot;_dynamic_&quot;</span> &lt;&lt; next_id_++;</div><div class="line">            qn = os.str();</div><div class="line">        }</div><div class="line">        Queue* q = 0;</div><div class="line">        queues::iterator i = queues_.find(qn);</div><div class="line">        <span class="keywordflow">if</span> (i==queues_.end()) {</div><div class="line">            q = <span class="keyword">new</span> Queue(container_, qn);</div><div class="line">            queues_[qn] = q;</div><div class="line">        } <span class="keywordflow">else</span> {</div><div class="line">            q = i-&gt;second;</div><div class="line">        }</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(&amp;connection, &amp;T::boundQueue, &amp;connection, q, qn);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> findQueueSender(Sen
 der* s, std::string qn) {</div><div class="line">        findQueue(*s, qn);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> findQueueReceiver(Receiver* r, std::string qn) {</div><div class="line">        findQueue(*r, qn);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>connection_handler : <span class="keyword">public</span> <a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    QueueManager&amp; queue_manager_;</div><div class="line">    senders senders_;</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    connection_handler(QueueManager&amp; qm) :</div><div class="line">        queue_manager_(qm)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype"
 >void</span> on_connection_open(<a name="_a19"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; c) OVERRIDE {</div><div class="line">        c.open();            <span class="comment">// Accept the connection</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// A sender sends messages from a queue to a subscriber.</span></div><div class="line">    <span class="keywordtype">void</span> on_sender_open(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE {</div><div class="line">        std::string qn = sender.<a name="a20"></a><a class="code" href="classproton_1_1sender.html#a91a9e8a9445b29d83dd0514cd76503ae">source</a>().<a name="a21"></a><a class="code" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() ? <span class="stringliteral">&quot;&quot;</span> : sender.<a class="code" href="classproton_1_1sender.html#a91a9e8a9
 445b29d83dd0514cd76503ae">source</a>().<a name="a22"></a><a class="code" href="classproton_1_1source.html#a4744eb217c976c199b678bb5a0d55acf">address</a>();</div><div class="line">        Sender* s = <span class="keyword">new</span> Sender(sender, senders_);</div><div class="line">        senders_[sender] = s;</div><div class="line">        <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(&amp;queue_manager_, &amp;QueueManager::findQueueSender, &amp;queue_manager_, s, qn);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// A receiver receives messages from a publisher to a queue.</span></div><div class="line">    <span class="keywordtype">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> &amp;receiver) OVERRIDE {</div><div class="line">        std::string qname = receiver.target().address();</div><div class="line">        <sp
 an class="keywordflow">if</span> (qname == <span class="stringliteral">&quot;shutdown&quot;</span>) {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;broker shutting down&quot;</span> &lt;&lt; std::endl;</div><div class="line">            <span class="comment">// Sending to the special &quot;shutdown&quot; queue stops the broker.</span></div><div class="line">            receiver.connection().container().stop(</div><div class="line">                <a name="_a23"></a><a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>(<span class="stringliteral">&quot;shutdown&quot;</span>, <span class="stringliteral">&quot;stop broker&quot;</span>));</div><div class="line">        } <span class="keywordflow">else</span> {</div><div class="line">            <span class="keywordflow">if</span> (qname.empty()) {</div><div class="line">                DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;ODD - trying to att
 ach to a empty address\n&quot;</span>;);</div><div class="line">            }</div><div class="line">            Receiver* r = <span class="keyword">new</span> Receiver(receiver);</div><div class="line">            <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(&amp;queue_manager_, &amp;QueueManager::findQueueReceiver, &amp;queue_manager_, r, qname);</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_session_close(<a name="_a24"></a><a class="code" href="classproton_1_1session.html">proton::session</a> &amp;session) OVERRIDE {</div><div class="line">        <span class="comment">// Unsubscribe all senders that belong to session.</span></div><div class="line">        <span class="keywordflow">for</span> (proton::sender_iterator i = session.senders().begin(); i != session.senders().end(); ++i) {</div><div class="line">         
    senders::iterator j = senders_.find(*i);</div><div class="line">            <span class="keywordflow">if</span> (j == senders_.end()) <span class="keywordflow">continue</span>;</div><div class="line">            Sender* s = j-&gt;second;</div><div class="line">            <span class="keywordflow">if</span> (s-&gt;queue_) {</div><div class="line">                <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(s-&gt;queue_, &amp;Queue::unsubscribe, s-&gt;queue_, s);</div><div class="line">            }</div><div class="line">            senders_.erase(j);</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_error(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e) OVERRIDE {</div><div class="line">        std::cerr &lt;&lt; <span class="stringlitera
 l">&quot;error: &quot;</span> &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// The container calls on_transport_close() last.</span></div><div class="line">    <span class="keywordtype">void</span> on_transport_close(<a name="_a25"></a><a class="code" href="classproton_1_1transport.html">proton::transport</a>&amp; t) OVERRIDE {</div><div class="line">        <span class="comment">// Unsubscribe all senders.</span></div><div class="line">        <span class="keywordflow">for</span> (proton::sender_iterator i = t.connection().senders().begin(); i != t.connection().senders().end(); ++i) {</div><div class="line">            senders::iterator j = senders_.find(*i);</div><div class="line">            <span class="keywordflow">if</span> (j == senders_.end()) <span class="keywordflow">continue</span>;</div><div class="line">            Sender* s = j-&gt;second;</div><div class="line">            <s
 pan class="keywordflow">if</span> (s-&gt;queue_) {</div><div class="line">                <a class="code" href="namespaceproton.html#ae77a8638d584f5fc99a1bbaf218d2481">proton::schedule_work</a>(s-&gt;queue_, &amp;Queue::unsubscribe, s-&gt;queue_, s);</div><div class="line">            }</div><div class="line">        }</div><div class="line">        <span class="keyword">delete</span> <span class="keyword">this</span>;            <span class="comment">// All done.</span></div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>broker {</div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    broker(<span class="keyword">const</span> std::string addr) :</div><div class="line">        container_(<span class="stringliteral">&quot;broker&quot;</span>), queues_(container_), listener_(queues_)</div><div class="line">    {</div><div class="line">        container_.<a name="a26"><
 /a><a class="code" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>(addr, listener_);</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;broker listening on &quot;</span> &lt;&lt; addr &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> run() {</div><div class="line"><span class="preprocessor">#if PN_CPP_SUPPORTS_THREADS</span></div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;starting &quot;</span> &lt;&lt; std::thread::hardware_concurrency() &lt;&lt; <span class="stringliteral">&quot; listening threads\n&quot;</span>;</div><div class="line">        container_.<a name="a27"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>(std::thread::hardware_concurrency());</div><div class="line"><span class="preprocessor">#else</span></div><div class="line">      
   container_.<a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"><span class="preprocessor">#endif</span></div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="keyword">struct </span>listener : <span class="keyword">public</span> <a name="_a28"></a><a class="code" href="classproton_1_1listen__handler.html">proton::listen_handler</a> {</div><div class="line">        listener(QueueManager&amp; c) : queues_(c) {}</div><div class="line"></div><div class="line">        <a name="_a29"></a><a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a> on_accept(<a name="_a30"></a><a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp;) OVERRIDE{</div><div class="line">            <span class="keywordflow">return</span> <a class="code" href="classproton_1_1connection__op
 tions.html">proton::connection_options</a>().<a name="a31"></a><a class="code" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">handler</a>(*(<span class="keyword">new</span> connection_handler(queues_)));</div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keywordtype">void</span> on_error(<a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp;, <span class="keyword">const</span> std::string&amp; s) OVERRIDE {</div><div class="line">            std::cerr &lt;&lt; <span class="stringliteral">&quot;listen error: &quot;</span> &lt;&lt; s &lt;&lt; std::endl;</div><div class="line">            <span class="keywordflow">throw</span> std::runtime_error(s);</div><div class="line">        }</div><div class="line">        QueueManager&amp; queues_;</div><div class="line">    };</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1container.html">proton::co
 ntainer</a> container_;</div><div class="line">    QueueManager queues_;</div><div class="line">    listener listener_;</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    <span class="comment">// Command line options</span></div><div class="line">    std::string address(<span class="stringliteral">&quot;0.0.0.0&quot;</span>);</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_flag(verbose, <span class="charliteral">&#39;v&#39;</span>, <span class="stringliteral">&quot;verbose&quot;</span>, <span class="stringliteral">&quot;verbose (debugging) output&quot;</span>);</div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringl
 iteral">&quot;listen on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        verbose = <span class="keyword">false</span>;</div><div class="line">        opts.parse();</div><div class="line">        broker(address).run();</div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; <span class="stringliteral">&quot;broker shutdown: &quot;</span> &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div>
 <div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<p>A broker using the <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>. You can use this to run other examples that require an intermediary, or you can use any AMQP 1.0 broker. This broker creates queues automatically when a client tries to send or subscribe.</p>
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="co
 de" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="error__condition_8hpp.html">proton/error_condition.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listen__handler_8hpp.html">proton/listen_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="p
 reprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver__options_8hpp.html">proton/receiver_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender__options_8hpp.html">proton/sender_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="source__options_8hpp.html">proton/source_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="target_8hpp.html">proton/target.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="target__options_8hpp.html">proton/target_options.hpp<
 /a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8hpp.html">proton/transport.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;deque&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#if PN_CPP_HAS_STD_THREAD</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line">
 </div><div class="line"><span class="keywordtype">int</span> hardware_concurrency() {<span class="keywordflow">return</span> std::thread::hardware_concurrency();}</div><div class="line"><span class="preprocessor">#else</span></div><div class="line"><span class="keywordtype">int</span> hardware_concurrency() {<span class="keywordflow">return</span> 1;}</div><div class="line"><span class="preprocessor">#endif</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="comment">// This is a simplified model for a message broker, that only allows for</span></div><div class="line"><span class="comment">// messages to go to a single receiver.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// This broker is multithread safe and if compiled with C++11 with a multithreaded Proton</span></div><div class="line"><
 span class="comment">// binding library will use as many threads as there are thread resources available (usually</span></div><div class="line"><span class="comment">// cores)</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Queues are only created and never destroyed</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Broker Entities (that need to be individually serialised)</span></div><div class="line"><span class="comment">// QueueManager - Creates new queues, finds queues</span></div><div class="line"><span class="comment">// Queue        - Queues msgs, records subscribers, sends msgs to subscribers</span></div><div class="line"><span class="comment">// Connection   - Receives Messages from network, sends messages to network.</span></div><div class="line"></div><div class="line"><span class="comment">// Work</span></div><div class="line"><span class="comment">/
 / FindQueue(queueName, connection) - From a Connection to the QueueManager</span></div><div class="line"><span class="comment">//     This will create the queue if it doesn&#39;t already exist and send a BoundQueue</span></div><div class="line"><span class="comment">//     message back to the connection.</span></div><div class="line"><span class="comment">// BoundQueue(queue) - From the QueueManager to a Connection</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// QueueMsg(msg)        - From a Connection (receiver) to a Queue</span></div><div class="line"><span class="comment">// Subscribe(sender)    - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">// Flow(sender, credit) - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">// Unsubscribe(sender)  - From a Connection (sender) to a Queue</span></div><div class="line"><span class="comment">//</s
 pan></div><div class="line"><span class="comment">// SendMsg(msg)   - From a Queue to a Connection (sender)</span></div><div class="line"><span class="comment">// Unsubscribed() - From a Queue to a Connection (sender)</span></div><div class="line"></div><div class="line"></div><div class="line"><span class="comment">// Simple debug output</span></div><div class="line"><span class="keywordtype">bool</span> verbose;</div><div class="line"><span class="preprocessor">#define DOUT(x) do {if (verbose) {x};} while (false)</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>Queue;</div><div class="line"><span class="keyword">class </span>Sender;</div><div class="line"></div><div class="line"><span class="keyword">typedef</span> std::map&lt;proton::sender, Sender*&gt; senders;</div><div class="line"></div><div class="line"><span class="keyword">class </span>Sender : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_
 1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">friend</span> <span class="keyword">class </span>connection_handler;</div><div class="line"></div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line">    senders&amp; senders_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>&amp; work_queue_;</div><div class="line">    std::string queue_name_;</div><div class="line">    Queue* queue_;</div><div class="line">    <span class="keywordtype">int</span> pending_credit_;</div><div class="line"></div><div class="line">    <span class="comment">// Messaging handlers</span></div><div class="line">    <span class="keywordtype">void</span> <a name="a3"></a><a class="code" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">on_sendable</a>(<a class="co
 de" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE;</div><div class="line">    <span class="keywordtype">void</span> <a name="a4"></a><a class="code" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29">on_sender_close</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE;</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Sender(<a class="code" href="classproton_1_1sender.html">proton::sender</a> s, senders&amp; ss) :</div><div class="line">        sender_(s), senders_(ss), work_queue_(s.<a name="a5"></a><a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>()), queue_(0), pending_credit_(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(proton::work f) {</div><div class="line">        <span class="keywordflow">r
 eturn</span> work_queue_.<a name="a6"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> boundQueue(Queue* q, std::string qn);</div><div class="line">    <span class="keywordtype">void</span> sendMsg(<a name="_a7"></a><a class="code" href="classproton_1_1message.html">proton::message</a> m) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; sending\n&quot;</span>;);</div><div class="line">        sender_.<a name="a8"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> unsubscribed() {</div><div class="
 line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; deleting\n&quot;</span>;);</div><div class="line">        <span class="keyword">delete</span> <span class="keyword">this</span>;</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// Queue - round robin subscriptions</span></div><div class="line"><span class="keyword">class </span>Queue {</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> work_queue_;</div><div class="line">    <span class="keyword">const</span> std::string name_;</div><div class="line">    std::deque&lt;proton::message&gt; messages_;</div><div class="line">    <span class="keyword">typedef</span> std::map&lt;Sender*, int&gt; subscriptions; <span class="comment">// With credit</span></div><div class="line">    s
 ubscriptions subscriptions_;</div><div class="line">    subscriptions::iterator current_;</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> tryToSend() {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; tryToSend: &quot;</span> &lt;&lt; subscriptions_.size(););</div><div class="line">        <span class="comment">// Starting at current_, send messages to subscriptions with credit:</span></div><div class="line">        <span class="comment">// After each send try to find another subscription; Wrap around;</span></div><div class="line">        <span class="comment">// Finish when we run out of messages or credit.</span></div><div class="line">        <span class="keywordtype">size_t</span> outOfCredit = 0;</div><div class="line">        <span class="keywordflow">while</span> (!messages_.empty() &am
 p;&amp; outOfCredit&lt;subscriptions_.size()) {</div><div class="line">            <span class="comment">// If we got the end (or haven&#39;t started yet) start at the beginning</span></div><div class="line">            <span class="keywordflow">if</span> (current_==subscriptions_.end()) {</div><div class="line">                current_=subscriptions_.begin();</div><div class="line">            }</div><div class="line">            <span class="comment">// If we have credit send the message</span></div><div class="line">            DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; current_-&gt;second &lt;&lt; <span class="stringliteral">&quot;) &quot;</span>;);</div><div class="line">            <span class="keywordflow">if</span> (current_-&gt;second&gt;0) {</div><div class="line">                DOUT(std::cerr &lt;&lt; current_-&gt;first &lt;&lt; <span class="stringliteral">&quot; &quot;</span>;);</div><div class="line">                current_-&gt;f
 irst-&gt;add(make_work(&amp;Sender::sendMsg, current_-&gt;first, messages_.front()));</div><div class="line">                messages_.pop_front();</div><div class="line">                --current_-&gt;second;</div><div class="line">                ++current_;</div><div class="line">            } <span class="keywordflow">else</span> {</div><div class="line">                ++outOfCredit;</div><div class="line">            }</div><div class="line">        }</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">    }</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Queue(<a name="_a9"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; c, <span class="keyword">const</span> std::string&amp; n) :</div><div class="line">        work_queue_(c), name_(n), current_(subscriptions_.end())</div><div class="line">    {}</div>
 <div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(proton::work f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> queueMsg(<a class="code" href="classproton_1_1message.html">proton::message</a> m) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) queueMsg\n&quot;</span>;);</div><div class="line">        messages_.push_back(m);</div><div class="line">        tryToSend();</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> flow(Sende
 r* s, <span class="keywordtype">int</span> c) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) flow: &quot;</span> &lt;&lt; c &lt;&lt; <span class="stringliteral">&quot; to &quot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        subscriptions_[s] = c;</div><div class="line">        tryToSend();</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> subscribe(Sender* s) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) subscribe Sender: &qu
 ot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        subscriptions_[s] = 0;</div><div class="line">    }</div><div class="line">    <span class="keywordtype">void</span> unsubscribe(Sender* s) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Queue:    &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; name_ &lt;&lt; <span class="stringliteral">&quot;) unsubscribe Sender: &quot;</span> &lt;&lt; s &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        <span class="comment">// If we&#39;re about to erase the current subscription move on</span></div><div class="line">        <span class="keywordflow">if</span> (current_ != subscriptions_.end() &amp;&amp; current_-&gt;first==s) ++current_;</div><div class="line">        subscriptions_.erase(s);</div><div class="line">        s
 -&gt;add(make_work(&amp;Sender::unsubscribed, s));</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="comment">// We have credit to send a message.</span></div><div class="line"><span class="keywordtype">void</span> Sender::on_sendable(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) {</div><div class="line">    <span class="keywordflow">if</span> (queue_) {</div><div class="line">        queue_-&gt;add(make_work(&amp;Queue::flow, queue_, <span class="keyword">this</span>, sender.<a name="a10"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>()));</div><div class="line">    } <span class="keywordflow">else</span> {</div><div class="line">        pending_credit_ = sender.<a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>();</div><div class="line">    }</div><div class="line">}</div><div class="line"><
 /div><div class="line"><span class="keywordtype">void</span> Sender::on_sender_close(<a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) {</div><div class="line">    <span class="keywordflow">if</span> (queue_) {</div><div class="line">        queue_-&gt;add(make_work(&amp;Queue::unsubscribe, queue_, <span class="keyword">this</span>));</div><div class="line">    } <span class="keywordflow">else</span> {</div><div class="line">        <span class="comment">// TODO: Is it possible to be closed before we get the queue allocated?</span></div><div class="line">        <span class="comment">// If so, we should have a way to mark the sender deleted, so we can delete</span></div><div class="line">        <span class="comment">// on queue binding</span></div><div class="line">    }</div><div class="line">    senders_.erase(sender);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> Sender::boundQueue(Qu
 eue* q, std::string qn) {</div><div class="line">    DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Sender:   &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; bound to Queue: &quot;</span> &lt;&lt; q &lt;&lt;<span class="stringliteral">&quot;(&quot;</span> &lt;&lt; qn &lt;&lt; <span class="stringliteral">&quot;)\n&quot;</span>;);</div><div class="line">    queue_ = q;</div><div class="line">    queue_name_ = qn;</div><div class="line"></div><div class="line">    q-&gt;add(make_work(&amp;Queue::subscribe, q, <span class="keyword">this</span>));</div><div class="line">    sender_.open(<a name="_a11"></a><a class="code" href="classproton_1_1sender__options.html">proton::sender_options</a>()</div><div class="line">        .source((<a name="_a12"></a><a class="code" href="classproton_1_1source__options.html">proton::source_options</a>().address(queue_name_)))</div><div class="line">        .handler(*<span class="keyword">this
 </span>));</div><div class="line">    <span class="keywordflow">if</span> (pending_credit_&gt;0) {</div><div class="line">        queue_-&gt;add(make_work(&amp;Queue::flow, queue_, <span class="keyword">this</span>, pending_credit_));</div><div class="line">    }</div><div class="line">    std::cout &lt;&lt; <span class="stringliteral">&quot;sending from &quot;</span> &lt;&lt; queue_name_ &lt;&lt; std::endl;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">class </span>Receiver : <span class="keyword">public</span> <a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="keyword">friend</span> <span class="keyword">class </span>connection_handler;</div><div class="line"></div><div class="line">    <a name="_a13"></a><a class="code" href="classproton_1_1receiver.html">proton::receiver</a> receiver_;</div><div class="line">    <a class="code" href="classproton_1_1w
 ork__queue.html">proton::work_queue</a>&amp; work_queue_;</div><div class="line">    Queue* queue_;</div><div class="line">    std::deque&lt;proton::message&gt; messages_;</div><div class="line"></div><div class="line">    <span class="comment">// A message is received.</span></div><div class="line">    <span class="keywordtype">void</span> on_message(<a name="_a14"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m) OVERRIDE {</div><div class="line">        messages_.push_back(m);</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (queue_) {</div><div class="line">            queueMsgs();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> queueMsgs() {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&
 quot;Receiver: &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; queueing &quot;</span> &lt;&lt; messages_.size() &lt;&lt; <span class="stringliteral">&quot; msgs to: &quot;</span> &lt;&lt; queue_ &lt;&lt; <span class="stringliteral">&quot;\n&quot;</span>;);</div><div class="line">        <span class="keywordflow">while</span> (!messages_.empty()) {</div><div class="line">            queue_-&gt;add(make_work(&amp;Queue::queueMsg, queue_, messages_.front()));</div><div class="line">            messages_.pop_front();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    Receiver(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> r) :</div><div class="line">        receiver_(r), work_queue_(r.<a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>()), queue
 _(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(proton::work f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> boundQueue(Queue* q, std::string qn) {</div><div class="line">        DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;Receiver: &quot;</span> &lt;&lt; <span class="keyword">this</span> &lt;&lt; <span class="stringliteral">&quot; bound to Queue: &quot;</span> &lt;&lt; q &lt;&lt; <span class="stringliteral">&quot;(&quot;</span> &lt;&lt; qn &lt;&lt; <span class="stringliteral">&quot;)\n&quot;</span>;);</div><div class="line">        queue_ = q;</div><div class="line">        receiver_.<a name="a15"></a><a class="code" href="classproton_
 1_1receiver.html#a9e8555112049fc2b4945120b3c45f8ab">open</a>(<a name="_a16"></a><a class="code" href="classproton_1_1receiver__options.html">proton::receiver_options</a>()</div><div class="line">            .source((<a class="code" href="classproton_1_1source__options.html">proton::source_options</a>().address(qn)))</div><div class="line">            .handler(*<span class="keyword">this</span>));</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;receiving to &quot;</span> &lt;&lt; qn &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        queueMsgs();</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>QueueManager {</div><div class="line">    <a class="code" href="classproton_1_1container.html">proton::container</a>&amp; container_;</div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> work_queue
 _;</div><div class="line">    <span class="keyword">typedef</span> std::map&lt;std::string, Queue*&gt; queues;</div><div class="line">    queues queues_;</div><div class="line">    <span class="keywordtype">int</span> next_id_; <span class="comment">// Use to generate unique queue IDs.</span></div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    QueueManager(<a class="code" href="classproton_1_1container.html">proton::container</a>&amp; c) :</div><div class="line">        container_(c), work_queue_(c), next_id_(0)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">bool</span> add(proton::work f) {</div><div class="line">        <span class="keywordflow">return</span> work_queue_.<a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>(f);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="ke
 yword">template</span> &lt;<span class="keyword">class</span> T&gt;</div><div class="line">    <span class="keywordtype">void</span> findQueue(T&amp; connection, std::string&amp; qn) {</div><div class="line">        <span class="keywordflow">if</span> (qn.empty()) {</div><div class="line">            <span class="comment">// Dynamic queue creation</span></div><div class="line">            std::ostringstream os;</div><div class="line">            os &lt;&lt; <span class="stringliteral">&quot;_dynamic_&quot;</span> &lt;&lt; next_id_++;</div><div class="line">            qn = os.str();</div><div class="line">        }</div><div class="line">        Queue* q = 0;</div><div class="line">        queues::iterator i = queues_.find(qn);</div><div class="line">        <span class="keywordflow">if</span> (i==queues_.end()) {</div><div class="line">            q = <span class="keyword">new</span> Queue(container_, qn);</div><div class="line">            queues_[qn] = q;</div><div class="line"> 
        } <span class="keywordflow">else</span> {</div><div class="line">            q = i-&gt;second;</div><div class="line">        }</div><div class="line">        connection.add(make_work(&amp;T::boundQueue, &amp;connection, q, qn));</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> findQueueSender(Sender* s, std::string qn) {</div><div class="line">        findQueue(*s, qn);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> findQueueReceiver(Receiver* r, std::string qn) {</div><div class="line">        findQueue(*r, qn);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>connection_handler : <span class="keyword">public</span> <a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    QueueManager&am
 p; queue_manager_;</div><div class="line">    senders senders_;</div><div class="line"></div><div class="line"><span class="keyword">public</span>:</div><div class="line">    connection_handler(QueueManager&amp; qm) :</div><div class="line">        queue_manager_(qm)</div><div class="line">    {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_connection_open(<a name="_a17"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; c) OVERRIDE {</div><div class="line">        c.<a name="a18"></a><a class="code" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab">open</a>();            <span class="comment">// Accept the connection</span></div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// A sender sends messages from a queue to a subscriber.</span></div><div class="line">    <span class="keywordtype">void</span> on_sender_open(<a class="code
 " href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE {</div><div class="line">        std::string qn = sender.<a name="a19"></a><a class="code" href="classproton_1_1sender.html#a91a9e8a9445b29d83dd0514cd76503ae">source</a>().<a name="a20"></a><a class="code" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() ? <span class="stringliteral">&quot;&quot;</span> : sender.<a class="code" href="classproton_1_1sender.html#a91a9e8a9445b29d83dd0514cd76503ae">source</a>().<a name="a21"></a><a class="code" href="classproton_1_1source.html#a4744eb217c976c199b678bb5a0d55acf">address</a>();</div><div class="line">        Sender* s = <span class="keyword">new</span> Sender(sender, senders_);</div><div class="line">        senders_[sender] = s;</div><div class="line">        queue_manager_.add(make_work(&amp;QueueManager::findQueueSender, &amp;queue_manager_, s, qn));</div><div class="line">    }</div><div class="line"></div><div class="line">
     <span class="comment">// A receiver receives messages from a publisher to a queue.</span></div><div class="line">    <span class="keywordtype">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">proton::receiver</a> &amp;receiver) OVERRIDE {</div><div class="line">        std::string qname = receiver.<a name="a22"></a><a class="code" href="classproton_1_1receiver.html#a5f0b815f331997411a6794f8628592ba">target</a>().<a name="a23"></a><a class="code" href="classproton_1_1target.html#a4744eb217c976c199b678bb5a0d55acf">address</a>();</div><div class="line">        <span class="keywordflow">if</span> (qname == <span class="stringliteral">&quot;shutdown&quot;</span>) {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;broker shutting down&quot;</span> &lt;&lt; std::endl;</div><div class="line">            <span class="comment">// Sending to the special &quot;shutdown&quot; queue stops the broker.</span></div><div class
 ="line">            receiver.<a name="a24"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a25"></a><a class="code" href="classproton_1_1connection.html#a2f632b80247e868b8264b8a025b84baf">container</a>().<a name="a26"></a><a class="code" href="classproton_1_1container.html#ade42a19caab198f0fd1d28e03cf9ba0e">stop</a>(</div><div class="line">                <a name="_a27"></a><a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>(<span class="stringliteral">&quot;shutdown&quot;</span>, <span class="stringliteral">&quot;stop broker&quot;</span>));</div><div class="line">        } <span class="keywordflow">else</span> {</div><div class="line">            <span class="keywordflow">if</span> (qname.empty()) {</div><div class="line">                DOUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;ODD - trying to attach to a empty address\n&quot;</span>;);</div><div class="line">       
      }</div><div class="line">            Receiver* r = <span class="keyword">new</span> Receiver(receiver);</div><div class="line">            queue_manager_.add(make_work(&amp;QueueManager::findQueueReceiver, &amp;queue_manager_, r, qname));</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_session_close(<a name="_a28"></a><a class="code" href="classproton_1_1session.html">proton::session</a> &amp;session) OVERRIDE {</div><div class="line">        <span class="comment">// Unsubscribe all senders that belong to session.</span></div><div class="line">        <span class="keywordflow">for</span> (proton::sender_iterator i = session.<a name="a29"></a><a class="code" href="classproton_1_1session.html#a2e6d8395032b1d590a9e1586c7de0fb5">senders</a>().begin(); i != session.<a class="code" href="classproton_1_1session.html#a2e6d8395032b1d590a9e1586c7de0fb5">senders</a>().end(); ++i) {</d
 iv><div class="line">            senders::iterator j = senders_.find(*i);</div><div class="line">            <span class="keywordflow">if</span> (j == senders_.end()) <span class="keywordflow">continue</span>;</div><div class="line">            Sender* s = j-&gt;second;</div><div class="line">            <span class="keywordflow">if</span> (s-&gt;queue_) {</div><div class="line">                s-&gt;queue_-&gt;add(make_work(&amp;Queue::unsubscribe, s-&gt;queue_, s));</div><div class="line">            }</div><div class="line">            senders_.erase(j);</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_error(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e) OVERRIDE {</div><div class="line">        std::cerr &lt;&lt; <span class="stringliteral">&quot;error: &quot;</span> &lt;&lt; e.<a name="a30"><
 /a><a class="code" href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">what</a>() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// The container calls on_transport_close() last.</span></div><div class="line">    <span class="keywordtype">void</span> on_transport_close(<a name="_a31"></a><a class="code" href="classproton_1_1transport.html">proton::transport</a>&amp; t) OVERRIDE {</div><div class="line">        <span class="comment">// Unsubscribe all senders.</span></div><div class="line">        <span class="keywordflow">for</span> (proton::sender_iterator i = t.<a name="a32"></a><a class="code" href="classproton_1_1transport.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a33"></a><a class="code" href="classproton_1_1connection.html#a2e6d8395032b1d590a9e1586c7de0fb5">senders</a>().begin(); i != t.<a class="code" href="classproton_1_1transport.html#aff302bb6016f2ae
 29f01bb4e07389a52">connection</a>().<a class="code" href="classproton_1_1connection.html#a2e6d8395032b1d590a9e1586c7de0fb5">senders</a>().end(); ++i) {</div><div class="line">            senders::iterator j = senders_.find(*i);</div><div class="line">            <span class="keywordflow">if</span> (j == senders_.end()) <span class="keywordflow">continue</span>;</div><div class="line">            Sender* s = j-&gt;second;</div><div class="line">            <span class="keywordflow">if</span> (s-&gt;queue_) {</div><div class="line">                s-&gt;queue_-&gt;add(make_work(&amp;Queue::unsubscribe, s-&gt;queue_, s));</div><div class="line">            }</div><div class="line">        }</div><div class="line">        <span class="keyword">delete</span> <span class="keyword">this</span>;            <span class="comment">// All done.</span></div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keyword">class </span>broker {
 </div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    broker(<span class="keyword">const</span> std::string addr) :</div><div class="line">        container_(<span class="stringliteral">&quot;broker&quot;</span>), queues_(container_), listener_(queues_)</div><div class="line">    {</div><div class="line">        container_.listen(addr, listener_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> run() {</div><div class="line"><span class="preprocessor">#if PN_CPP_SUPPORTS_THREADS</span></div><div class="line">        <span class="keywordtype">int</span> threads = hardware_concurrency();</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;starting &quot;</span> &lt;&lt; threads &lt;&lt; <span class="stringliteral">&quot; listening threads\n&quot;</span>;</div><div class="line">        std::cout.flush();</div><div class="line">        container_.run(
 threads);</div><div class="line"><span class="preprocessor">#else</span></div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;no thread support - starting 1 listening thread\n&quot;</span>;</div><div class="line">        std::cout.flush();</div><div class="line">        container_.run();</div><div class="line"><span class="preprocessor">#endif</span></div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="keyword">struct </span>listener : <span class="keyword">public</span> <a name="_a34"></a><a class="code" href="classproton_1_1listen__handler.html">proton::listen_handler</a> {</div><div class="line">        listener(QueueManager&amp; c) : queues_(c) {}</div><div class="line"></div><div class="line">        <a name="_a35"></a><a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a> on_accept(<a name="_a36"></a><a cla
 ss="code" href="classproton_1_1listener.html">proton::listener</a>&amp;) OVERRIDE{</div><div class="line">            <span class="keywordflow">return</span> <a class="code" href="classproton_1_1connection__options.html">proton::connection_options</a>().<a name="a37"></a><a class="code" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504">handler</a>(*(<span class="keyword">new</span> connection_handler(queues_)));</div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keywordtype">void</span> on_open(<a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp; l) OVERRIDE {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;broker listening on &quot;</span> &lt;&lt; l.<a name="a38"></a><a class="code" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">port</a>() &lt;&lt; std::endl;</div><div class="line">        }</div><div class="line">
 </div><div class="line">        <span class="keywordtype">void</span> on_error(<a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp;, <span class="keyword">const</span> std::string&amp; s) OVERRIDE {</div><div class="line">            std::cerr &lt;&lt; <span class="stringliteral">&quot;listen error: &quot;</span> &lt;&lt; s &lt;&lt; std::endl;</div><div class="line">            <span class="keywordflow">throw</span> std::runtime_error(s);</div><div class="line">        }</div><div class="line">        QueueManager&amp; queues_;</div><div class="line">    };</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1container.html">proton::container</a> container_;</div><div class="line">    QueueManager queues_;</div><div class="line">    listener listener_;</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="key
 wordtype">char</span> **argv) {</div><div class="line">    <span class="comment">// Command line options</span></div><div class="line">    std::string address(<span class="stringliteral">&quot;0.0.0.0&quot;</span>);</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_flag(verbose, <span class="charliteral">&#39;v&#39;</span>, <span class="stringliteral">&quot;verbose&quot;</span>, <span class="stringliteral">&quot;verbose (debugging) output&quot;</span>);</div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;listen on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        verbose = <span class="keyword">false</span>;</div><div class="line">        o
 pts.parse();</div><div class="line">        broker(address).run();</div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; <span class="stringliteral">&quot;broker shutdown: &quot;</span> &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[35/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreedata.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreedata.js b/content/releases/qpid-proton-master/proton/c/api/navtreedata.js
index c1834da..4e6c819 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreedata.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreedata.js
@@ -3,6 +3,7 @@ var NAVTREE =
   [ "Qpid Proton C API", "index.html", [
     [ "Introduction", "index.html", null ],
     [ "IO integration", "io_page.html", null ],
+    [ "Deprecated List", "deprecated.html", null ],
     [ "Modules", "modules.html", "modules" ],
     [ "Classes", "annotated.html", [
       [ "Class List", "annotated.html", "annotated_dup" ],
@@ -21,19 +22,20 @@ var NAVTREE =
         [ "Enumerator", "globals_eval.html", null ],
         [ "Macros", "globals_defs.html", null ]
       ] ]
-    ] ]
+    ] ],
+    [ "Examples", "examples.html", "examples" ]
   ] ]
 ];
 
 var NAVTREEINDEX =
 [
 "annotated.html",
-"group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0",
-"group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81",
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498",
-"group__message.html#gacb97f21822b058b6297bc618f6d190b0",
-"group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56",
-"group__transport.html#ga4695788da8491f0c7104bfe36634ff94"
+"group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a",
+"group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb",
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e",
+"group__message.html#gaa8594da8507dc031b1e0e89d51a2f281",
+"group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c",
+"group__transport.html#ga09a0d15514ca9a14eb40f12425a52797"
 ];
 
 var SYNCONMSG = 'click to disable panel synchronisation';

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex0.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex0.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex0.js
index 5976404..dd308b0 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex0.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex0.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX0 =
 {
-"annotated.html":[3,0],
-"codec_8h.html":[4,0,0,0],
-"codec_8h_source.html":[4,0,0,0],
-"condition_8h.html":[4,0,0,1],
-"condition_8h_source.html":[4,0,0,1],
-"connection_8h.html":[4,0,0,2],
-"connection_8h_source.html":[4,0,0,2],
-"connection__driver_8h.html":[4,0,0,3],
-"connection__driver_8h_source.html":[4,0,0,3],
-"delivery_8h.html":[4,0,0,4],
-"delivery_8h_source.html":[4,0,0,4],
-"dir_25143d27009f52d175c1d192441a738a.html":[4,0,0],
-"disposition_8h.html":[4,0,0,5],
-"disposition_8h_source.html":[4,0,0,5],
-"error_8h.html":[4,0,0,6],
-"error_8h_source.html":[4,0,0,6],
-"event_8h.html":[4,0,0,7],
-"event_8h_source.html":[4,0,0,7],
-"files.html":[4,0],
-"functions.html":[3,1,0],
-"functions_vars.html":[3,1,1],
-"globals.html":[4,1,0],
-"globals.html":[4,1,0,0],
-"globals_b.html":[4,1,0,1],
-"globals_c.html":[4,1,0,2],
-"globals_d.html":[4,1,0,3],
-"globals_defs.html":[4,1,5],
-"globals_e.html":[4,1,0,4],
-"globals_enum.html":[4,1,3],
-"globals_eval.html":[4,1,4],
-"globals_f.html":[4,1,0,5],
-"globals_func.html":[4,1,1],
-"globals_func.html":[4,1,1,0],
-"globals_func_c.html":[4,1,1,1],
-"globals_func_d.html":[4,1,1,2],
-"globals_func_e.html":[4,1,1,3],
-"globals_func_l.html":[4,1,1,4],
-"globals_func_m.html":[4,1,1,5],
-"globals_func_n.html":[4,1,1,6],
-"globals_func_p.html":[4,1,1,7],
-"globals_func_r.html":[4,1,1,8],
-"globals_func_s.html":[4,1,1,9],
-"globals_func_t.html":[4,1,1,10],
-"globals_func_u.html":[4,1,1,11],
-"globals_func_w.html":[4,1,1,12],
-"globals_i.html":[4,1,0,6],
-"globals_l.html":[4,1,0,7],
-"globals_m.html":[4,1,0,8],
-"globals_n.html":[4,1,0,9],
-"globals_o.html":[4,1,0,10],
-"globals_p.html":[4,1,0,11],
-"globals_r.html":[4,1,0,12],
-"globals_s.html":[4,1,0,13],
-"globals_t.html":[4,1,0,14],
-"globals_type.html":[4,1,2],
-"globals_u.html":[4,1,0,15],
-"globals_w.html":[4,1,0,16],
-"group__amqp__types.html":[2,1,0],
-"group__amqp__types.html#afdf37091f4247c81d253716eab97020e":[2,1,0,0,0],
-"group__amqp__types.html#afdf37091f4247c81d253716eab97020e":[2,1,0,1,0],
-"group__amqp__types.html#ga4465b5ea7d3c4f15c1dffa4deda905db":[4,0,0,0,1],
-"group__amqp__types.html#ga4465b5ea7d3c4f15c1dffa4deda905db":[2,1,0,6],
-"group__amqp__types.html#ga48a3094a983392e095984f1db2ec4fe3":[2,1,0,7],
-"group__amqp__types.html#ga48a3094a983392e095984f1db2ec4fe3":[4,0,0,0,2],
-"group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44":[4,0,0,19,6],
-"group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44":[2,1,0,4],
-"group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f":[4,0,0,19,7],
-"group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f":[2,1,0,5],
-"group__amqp__types.html#gaa1713f25d484600197d2a25ace856672":[4,0,0,19,5],
-"group__amqp__types.html#gaa1713f25d484600197d2a25ace856672":[2,1,0,3],
-"group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd":[4,0,0,19,4],
-"group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd":[2,1,0,2],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13":[2,1,0,6,17],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13":[4,0,0,0,1,17],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba175c594857c135ea2a9c3a2d415366ab":[2,1,0,6,7],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba175c594857c135ea2a9c3a2d415366ab":[4,0,0,0,1,7],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2c6f15d0ad9e27f040382ef4a2be807d":[2,1,0,6,22],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2c6f15d0ad9e27f040382ef4a2be807d":[4,0,0,0,1,22],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2d6444a931a66258de3c73ad01238ae7":[4,0,0,0,1,1],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2d6444a931a66258de3c73ad01238ae7":[2,1,0,6,1],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3295ee98cb6c69f50951aea30ffe46dd":[2,1,0,6,24],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3295ee98cb6c69f50951aea30ffe46dd":[4,0,0,0,1,24],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba32d7a9a461945791cb02902af9ff6592":[4,0,0,0,1,3],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba32d7a9a461945791cb02902af9ff6592":[2,1,0,6,3],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3dbf1221e02329a7f41b41e597833d97":[4,0,0,0,1,5],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3dbf1221e02329a7f41b41e597833d97":[2,1,0,6,5],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba5f6b5fd2edbedf3f21285b69b8864777":[2,1,0,6,9],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba5f6b5fd2edbedf3f21285b69b8864777":[4,0,0,0,1,9],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba653d98ae82ff7048973b4c755d2b2804":[2,1,0,6,23],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba653d98ae82ff7048973b4c755d2b2804":[4,0,0,0,1,23],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba657a836a5ee74d9468924982ba3a3b41":[4,0,0,0,1,4],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba657a836a5ee74d9468924982ba3a3b41":[2,1,0,6,4],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7a1b08f15b17b3d820a6fb50e65ffe1c":[2,1,0,6,10],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7a1b08f15b17b3d820a6fb50e65ffe1c":[4,0,0,0,1,10],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7dc0fd4874c2b57a8249614d348643e9":[2,1,0,6,18],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7dc0fd4874c2b57a8249614d348643e9":[4,0,0,0,1,18],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba88421417c7be2caf88c2d243cb73da6b":[2,1,0,6,19],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba88421417c7be2caf88c2d243cb73da6b":[4,0,0,0,1,19],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba891d1f2ee5621729cd5a07593042dce6":[2,1,0,6,25],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba891d1f2ee5621729cd5a07593042dce6":[4,0,0,0,1,25],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba905512ea57a64d4e2aecf4877b192124":[2,1,0,6,8],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba905512ea57a64d4e2aecf4877b192124":[4,0,0,0,1,8],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba99223ec8d1ae5d915a1eaa7e8fef0256":[4,0,0,0,1,2],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba99223ec8d1ae5d915a1eaa7e8fef0256":[2,1,0,6,2],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0":[2,1,0,6,12],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0":[4,0,0,0,1,12],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa1367e8029855849dc4e0d3f027279a5":[2,1,0,6,13],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa1367e8029855849dc4e0d3f027279a5":[4,0,0,0,1,13],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa7a251ed9fe5c31f0473976467bfefdd":[2,1,0,6,6],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa7a251ed9fe5c31f0473976467bfefdd":[4,0,0,0,1,6],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaca241b4fa6cd92fdf26b4460d02a17b1":[2,1,0,6,11],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaca241b4fa6cd92fdf26b4460d02a17b1":[4,0,0,0,1,11],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae":[2,1,0,6,15],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae":[4,0,0,0,1,15],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbad5f0929805f481d3ca6089ed172451e9":[2,1,0,6,20],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbad5f0929805f481d3ca6089ed172451e9":[4,0,0,0,1,20],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae54cf8095578932042be640555855cd4":[2,1,0,6,16],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae54cf8095578932042be640555855cd4":[4,0,0,0,1,16],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae998dd044ac55b959427fc90531b14ca":[2,1,0,6,14],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae998dd044ac55b959427fc90531b14ca":[4,0,0,0,1,14],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe":[4,0,0,0,1,0],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe":[2,1,0,6,0],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaff3c998d42222a4a4be01cac89418d07":[2,1,0,6,21],
-"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaff3c998d42222a4a4be01cac89418d07":[4,0,0,0,1,21],
-"group__amqp__types.html#structpn__decimal128__t":[2,1,0,0],
-"group__amqp__types.html#structpn__uuid__t":[2,1,0,1],
-"group__api__types.html":[2,1,1],
-"group__api__types.html#a27df760d7bd97cf728fc3e633a1ba604":[2,1,1,0,0],
-"group__api__types.html#a40718ebaefa0aa99686fb027a4dfc120":[2,1,1,0,1],
-"group__api__types.html#a854352f53b148adc24983a58a1866d66":[2,1,1,1,0],
-"group__api__types.html#a854352f53b148adc24983a58a1866d66":[2,1,1,2,0],
-"group__api__types.html#ab40328f79e021050ac262dc0a6019667":[2,1,1,2,1],
-"group__api__types.html#ac621bcfb466f3b6a6421c5f48b30ade3":[2,1,1,1,1],
-"group__api__types.html#ga1f6bde2a01737366adcbfee546035b78":[2,1,1,8],
-"group__api__types.html#ga1f6bde2a01737366adcbfee546035b78":[4,0,0,19,9],
-"group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748":[2,1,1,7],
-"group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748":[4,0,0,19,8],
-"group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64":[2,1,1,3],
-"group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64":[4,0,0,19,0],
-"group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606":[2,1,1,4],
-"group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606":[4,0,0,19,1],
-"group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c":[2,1,1,5],
-"group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c":[4,0,0,19,2],
-"group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca":[2,1,1,10],
-"group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca":[4,0,0,19,20],
-"group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb":[2,1,1,9],
-"group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb":[4,0,0,19,19],
-"group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1":[2,1,1,6],
-"group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1":[4,0,0,19,3],
-"group__api__types.html#structpn__atom__t":[2,1,1,0],
-"group__api__types.html#structpn__bytes__t":[2,1,1,1],
-"group__api__types.html#structpn__rwbytes__t":[2,1,1,2],
-"group__codec.html":[2,2],
-"group__condition.html":[2,0,6],
-"group__condition.html#ga05b0d374d90f11d9ebbf818662569689":[2,0,6,3],
-"group__condition.html#ga05b0d374d90f11d9ebbf818662569689":[4,0,0,1,3],
-"group__condition.html#ga112611a7a4087e050c476a430db2cfb9":[2,0,6,1],
-"group__condition.html#ga112611a7a4087e050c476a430db2cfb9":[4,0,0,1,1],
-"group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5":[2,0,6,0],
-"group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5":[4,0,0,1,0],
-"group__condition.html#ga1dba0d01af7ba6ad7ad6b02bf642a46b":[2,0,6,7],
-"group__condition.html#ga1dba0d01af7ba6ad7ad6b02bf642a46b":[4,0,0,1,7],
-"group__condition.html#ga65d9818487fc61e7ca75a9ec4abc8676":[2,0,6,9],
-"group__condition.html#ga65d9818487fc61e7ca75a9ec4abc8676":[4,0,0,1,9],
-"group__condition.html#ga76c5dbc715c0d72d7dad2126b797eb64":[2,0,6,11],
-"group__condition.html#ga76c5dbc715c0d72d7dad2126b797eb64":[4,0,0,1,11],
-"group__condition.html#ga8e7eacc5be9c2223535bb57950171f0b":[2,0,6,6],
-"group__condition.html#ga8e7eacc5be9c2223535bb57950171f0b":[4,0,0,1,6],
-"group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8":[2,0,6,5],
-"group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8":[4,0,0,1,5],
-"group__condition.html#gab344572fd2d80aa5c52b588129facb27":[2,0,6,4],
-"group__condition.html#gab344572fd2d80aa5c52b588129facb27":[4,0,0,1,4],
-"group__condition.html#gab91d5be5be6a61dc3d9dfaa4e01372b4":[2,0,6,2],
-"group__condition.html#gab91d5be5be6a61dc3d9dfaa4e01372b4":[4,0,0,1,2],
-"group__condition.html#gac798dc9acd131cb47a3e7291efffbc02":[2,0,6,14],
-"group__condition.html#gac798dc9acd131cb47a3e7291efffbc02":[4,0,0,1,14],
-"group__condition.html#gaccab52be69f97d7be2d199b4e1f11380":[2,0,6,8],
-"group__condition.html#gaccab52be69f97d7be2d199b4e1f11380":[4,0,0,1,8],
-"group__condition.html#gad1f52a60bcc855702cfe51e6703625bb":[2,0,6,15],
-"group__condition.html#gad1f52a60bcc855702cfe51e6703625bb":[4,0,0,1,15],
-"group__condition.html#gae495a2885d97a9f167e297efd6974a1e":[2,0,6,13],
-"group__condition.html#gae495a2885d97a9f167e297efd6974a1e":[4,0,0,1,13],
-"group__condition.html#gaefa0da2c1e82f29ddda357e171f5a50a":[2,0,6,10],
-"group__condition.html#gaefa0da2c1e82f29ddda357e171f5a50a":[4,0,0,1,10],
-"group__condition.html#gaf92a380a12c91d4124c22af62318c2e9":[2,0,6,12],
-"group__condition.html#gaf92a380a12c91d4124c22af62318c2e9":[4,0,0,1,12],
-"group__connection.html":[2,0,0],
-"group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e":[2,0,0,11],
-"group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e":[4,0,0,2,9],
-"group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb":[2,0,0,31],
-"group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb":[4,0,0,2,29],
-"group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa2b":[2,0,0,1],
-"group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa2b":[4,0,0,2,1],
-"group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8":[2,0,0,35],
-"group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8":[4,0,0,2,33],
-"group__connection.html#ga24a2d5aba432db549257993bfaa761dd":[2,0,0,39],
-"group__connection.html#ga24a2d5aba432db549257993bfaa761dd":[4,0,0,2,37],
-"group__connection.html#ga277d01dc2f87870ee260d43cf40abe13":[4,0,0,2,17],
-"group__connection.html#ga277d01dc2f87870ee260d43cf40abe13":[2,0,0,19],
-"group__connection.html#ga2fd2089e8eaa2a362606498f233ada61":[2,0,0,14],
-"group__connection.html#ga2fd2089e8eaa2a362606498f233ada61":[4,0,0,2,12],
-"group__connection.html#ga32329c4bb3e23607a243cd8100c01264":[2,0,0,6],
-"group__connection.html#ga32329c4bb3e23607a243cd8100c01264":[4,0,0,2,6],
-"group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3":[4,0,0,2,20],
-"group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3":[2,0,0,22],
-"group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c":[2,0,0,30],
-"group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c":[4,0,0,2,28],
-"group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670":[4,0,0,2,18],
-"group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670":[2,0,0,20],
-"group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3":[2,0,0,3],
-"group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3":[4,0,0,2,3],
-"group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07":[2,0,0,16],
-"group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07":[4,0,0,2,14],
-"group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8":[2,0,0,29],
-"group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8":[4,0,0,2,27],
-"group__connection.html#ga602c2c870ebed1d9bfe100876909225b":[2,0,0,2],
-"group__connection.html#ga602c2c870ebed1d9bfe100876909225b":[4,0,0,2,2],
-"group__connection.html#ga61e1f6386d18a568da50b998200eb87b":[2,0,0,25],
-"group__connection.html#ga61e1f6386d18a568da50b998200eb87b":[4,0,0,2,23],
-"group__connection.html#ga663c29ee6de4d522ba061224bc6240ad":[2,0,0,15],
-"group__connection.html#ga663c29ee6de4d522ba061224bc6240ad":[4,0,0,2,13],
-"group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3":[2,0,0,7],
-"group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3":[4,0,0,2,7],
-"group__connection.html#ga722d53b6063278fbcab5f814613c70ec":[2,0,0,38],
-"group__connection.html#ga722d53b6063278fbcab5f814613c70ec":[4,0,0,2,36],
-"group__connection.html#ga72a362389b99d8e891bf2e4fb4290754":[2,0,0,24],
-"group__connection.html#ga72a362389b99d8e891bf2e4fb4290754":[4,0,0,2,22],
-"group__connection.html#ga764c602a20457f9aa8862825b6d13a8d":[4,0,0,2,5],
-"group__connection.html#ga764c602a20457f9aa8862825b6d13a8d":[2,0,0,5],
-"group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5":[2,0,0,12],
-"group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5":[4,0,0,2,10],
-"group__connection.html#ga886351d81ff3a977a284a206526c5aff":[2,0,0,9],
-"group__connection.html#ga886351d81ff3a977a284a206526c5aff":[4,0,0,19,11],
-"group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285":[2,0,0,28],
-"group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285":[4,0,0,2,26],
-"group__connection.html#ga9bf90f0f395d26e320293063b70d040f":[2,0,0,37],
-"group__connection.html#ga9bf90f0f395d26e320293063b70d040f":[4,0,0,2,35],
-"group__connection.html#gaa83193a655e32bffc18624acc2c39233":[2,0,0,8],
-"group__connection.html#gaa83193a655e32bffc18624acc2c39233":[4,0,0,19,10],
-"group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d":[2,0,0,10],
-"group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d":[4,0,0,2,8],
-"group__connection.html#gaace04a030192f34747bb1ff3675c58f1":[4,0,0,2,21],
-"group__connection.html#gaace04a030192f34747bb1ff3675c58f1":[2,0,0,23],
-"group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a":[2,0,0,32],
-"group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a":[4,0,0,2,30],
-"group__connection.html#gabc8d505108a850837a0d2fb204875390":[2,0,0,34],
-"group__connection.html#gabc8d505108a850837a0d2fb204875390":[4,0,0,2,32],
-"group__connection.html#gabf25d7b763951b4a9c856536d6db0600":[2,0,0,33],
-"group__connection.html#gabf25d7b763951b4a9c856536d6db0600":[4,0,0,2,31],
-"group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0":[2,0,0,21]
+"annotated.html":[4,0],
+"broker_8c-example.html":[6,0],
+"cid_8h_source.html":[5,0,0,0],
+"codec_8h.html":[5,0,0,1],
+"codec_8h_source.html":[5,0,0,1],
+"condition_8h.html":[5,0,0,2],
+"condition_8h_source.html":[5,0,0,2],
+"connection_8h.html":[5,0,0,3],
+"connection_8h_source.html":[5,0,0,3],
+"connection__driver_8h.html":[5,0,0,4],
+"connection__driver_8h_source.html":[5,0,0,4],
+"delivery_8h.html":[5,0,0,5],
+"delivery_8h_source.html":[5,0,0,5],
+"deprecated.html":[2],
+"dir_25143d27009f52d175c1d192441a738a.html":[5,0,0],
+"direct_8c-example.html":[6,1],
+"disposition_8h.html":[5,0,0,6],
+"disposition_8h_source.html":[5,0,0,6],
+"engine_8h_source.html":[5,0,0,7],
+"error_8h.html":[5,0,0,8],
+"error_8h_source.html":[5,0,0,8],
+"event_8h.html":[5,0,0,9],
+"event_8h_source.html":[5,0,0,9],
+"examples.html":[6],
+"files.html":[5,0],
+"functions.html":[4,1,0],
+"functions_vars.html":[4,1,1],
+"globals.html":[5,1,0],
+"globals.html":[5,1,0,0],
+"globals_b.html":[5,1,0,1],
+"globals_c.html":[5,1,0,2],
+"globals_d.html":[5,1,0,3],
+"globals_defs.html":[5,1,5],
+"globals_e.html":[5,1,0,4],
+"globals_enum.html":[5,1,3],
+"globals_eval.html":[5,1,4],
+"globals_f.html":[5,1,0,5],
+"globals_func.html":[5,1,1],
+"globals_func.html":[5,1,1,0],
+"globals_func_c.html":[5,1,1,1],
+"globals_func_d.html":[5,1,1,2],
+"globals_func_e.html":[5,1,1,3],
+"globals_func_l.html":[5,1,1,4],
+"globals_func_m.html":[5,1,1,5],
+"globals_func_n.html":[5,1,1,6],
+"globals_func_p.html":[5,1,1,7],
+"globals_func_r.html":[5,1,1,8],
+"globals_func_s.html":[5,1,1,9],
+"globals_func_t.html":[5,1,1,10],
+"globals_func_u.html":[5,1,1,11],
+"globals_func_w.html":[5,1,1,12],
+"globals_i.html":[5,1,0,6],
+"globals_l.html":[5,1,0,7],
+"globals_m.html":[5,1,0,8],
+"globals_n.html":[5,1,0,9],
+"globals_o.html":[5,1,0,10],
+"globals_p.html":[5,1,0,11],
+"globals_r.html":[5,1,0,12],
+"globals_s.html":[5,1,0,13],
+"globals_t.html":[5,1,0,14],
+"globals_type.html":[5,1,2],
+"globals_u.html":[5,1,0,15],
+"globals_w.html":[5,1,0,16],
+"group__amqp__types.html":[3,1,0],
+"group__amqp__types.html#afdf37091f4247c81d253716eab97020e":[3,1,0,0,0],
+"group__amqp__types.html#afdf37091f4247c81d253716eab97020e":[3,1,0,1,0],
+"group__amqp__types.html#ga4465b5ea7d3c4f15c1dffa4deda905db":[5,0,0,1,1],
+"group__amqp__types.html#ga4465b5ea7d3c4f15c1dffa4deda905db":[3,1,0,6],
+"group__amqp__types.html#ga48a3094a983392e095984f1db2ec4fe3":[3,1,0,7],
+"group__amqp__types.html#ga48a3094a983392e095984f1db2ec4fe3":[5,0,0,1,2],
+"group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44":[5,0,0,29,6],
+"group__amqp__types.html#ga54d49ca7ff04ad10a57139c2d61f1d44":[3,1,0,4],
+"group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f":[5,0,0,29,7],
+"group__amqp__types.html#ga7d8110bc953738d83ad8b9c543ef517f":[3,1,0,5],
+"group__amqp__types.html#gaa1713f25d484600197d2a25ace856672":[5,0,0,29,5],
+"group__amqp__types.html#gaa1713f25d484600197d2a25ace856672":[3,1,0,3],
+"group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd":[5,0,0,29,4],
+"group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd":[3,1,0,2],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13":[3,1,0,6,17],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba0a6946e5c032bae8d108100e2c56ac13":[5,0,0,1,1,17],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba175c594857c135ea2a9c3a2d415366ab":[3,1,0,6,7],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba175c594857c135ea2a9c3a2d415366ab":[5,0,0,1,1,7],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2c6f15d0ad9e27f040382ef4a2be807d":[3,1,0,6,22],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2c6f15d0ad9e27f040382ef4a2be807d":[5,0,0,1,1,22],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2d6444a931a66258de3c73ad01238ae7":[3,1,0,6,1],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2d6444a931a66258de3c73ad01238ae7":[5,0,0,1,1,1],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3295ee98cb6c69f50951aea30ffe46dd":[3,1,0,6,24],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3295ee98cb6c69f50951aea30ffe46dd":[5,0,0,1,1,24],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba32d7a9a461945791cb02902af9ff6592":[3,1,0,6,3],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba32d7a9a461945791cb02902af9ff6592":[5,0,0,1,1,3],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3dbf1221e02329a7f41b41e597833d97":[3,1,0,6,5],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba3dbf1221e02329a7f41b41e597833d97":[5,0,0,1,1,5],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba5f6b5fd2edbedf3f21285b69b8864777":[3,1,0,6,9],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba5f6b5fd2edbedf3f21285b69b8864777":[5,0,0,1,1,9],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba653d98ae82ff7048973b4c755d2b2804":[3,1,0,6,23],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba653d98ae82ff7048973b4c755d2b2804":[5,0,0,1,1,23],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba657a836a5ee74d9468924982ba3a3b41":[3,1,0,6,4],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba657a836a5ee74d9468924982ba3a3b41":[5,0,0,1,1,4],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7a1b08f15b17b3d820a6fb50e65ffe1c":[3,1,0,6,10],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7a1b08f15b17b3d820a6fb50e65ffe1c":[5,0,0,1,1,10],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7dc0fd4874c2b57a8249614d348643e9":[3,1,0,6,18],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba7dc0fd4874c2b57a8249614d348643e9":[5,0,0,1,1,18],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba88421417c7be2caf88c2d243cb73da6b":[5,0,0,1,1,19],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba88421417c7be2caf88c2d243cb73da6b":[3,1,0,6,19],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba891d1f2ee5621729cd5a07593042dce6":[3,1,0,6,25],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba891d1f2ee5621729cd5a07593042dce6":[5,0,0,1,1,25],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba905512ea57a64d4e2aecf4877b192124":[3,1,0,6,8],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba905512ea57a64d4e2aecf4877b192124":[5,0,0,1,1,8],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba99223ec8d1ae5d915a1eaa7e8fef0256":[3,1,0,6,2],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba99223ec8d1ae5d915a1eaa7e8fef0256":[5,0,0,1,1,2],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0":[3,1,0,6,12],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba9c27cba605584c7d093f26e7270bfaa0":[5,0,0,1,1,12],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa1367e8029855849dc4e0d3f027279a5":[3,1,0,6,13],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa1367e8029855849dc4e0d3f027279a5":[5,0,0,1,1,13],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa7a251ed9fe5c31f0473976467bfefdd":[3,1,0,6,6],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaa7a251ed9fe5c31f0473976467bfefdd":[5,0,0,1,1,6],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaca241b4fa6cd92fdf26b4460d02a17b1":[3,1,0,6,11],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaca241b4fa6cd92fdf26b4460d02a17b1":[5,0,0,1,1,11],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae":[3,1,0,6,15],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbacb54239601b8bf4795e34417425b92ae":[5,0,0,1,1,15],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbad5f0929805f481d3ca6089ed172451e9":[3,1,0,6,20],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbad5f0929805f481d3ca6089ed172451e9":[5,0,0,1,1,20],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae54cf8095578932042be640555855cd4":[3,1,0,6,16],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae54cf8095578932042be640555855cd4":[5,0,0,1,1,16],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae998dd044ac55b959427fc90531b14ca":[3,1,0,6,14],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbae998dd044ac55b959427fc90531b14ca":[5,0,0,1,1,14],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe":[5,0,0,1,1,0],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaee48efaa3cb0c5b5d16c5b869b7e8fbe":[3,1,0,6,0],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaff3c998d42222a4a4be01cac89418d07":[3,1,0,6,21],
+"group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dbaff3c998d42222a4a4be01cac89418d07":[5,0,0,1,1,21],
+"group__amqp__types.html#structpn__decimal128__t":[3,1,0,0],
+"group__amqp__types.html#structpn__uuid__t":[3,1,0,1],
+"group__api__types.html":[3,1,1],
+"group__api__types.html#a27df760d7bd97cf728fc3e633a1ba604":[3,1,1,0,0],
+"group__api__types.html#a40718ebaefa0aa99686fb027a4dfc120":[3,1,1,0,1],
+"group__api__types.html#a854352f53b148adc24983a58a1866d66":[3,1,1,1,0],
+"group__api__types.html#a854352f53b148adc24983a58a1866d66":[3,1,1,2,0],
+"group__api__types.html#ab40328f79e021050ac262dc0a6019667":[3,1,1,2,1],
+"group__api__types.html#ac621bcfb466f3b6a6421c5f48b30ade3":[3,1,1,1,1],
+"group__api__types.html#ga1f6bde2a01737366adcbfee546035b78":[3,1,1,8],
+"group__api__types.html#ga1f6bde2a01737366adcbfee546035b78":[5,0,0,29,9],
+"group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748":[3,1,1,7],
+"group__api__types.html#ga26974f59df66946e2fe1f7e0ef5e9748":[5,0,0,29,8],
+"group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64":[3,1,1,3],
+"group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64":[5,0,0,29,0],
+"group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606":[3,1,1,4],
+"group__api__types.html#ga92033eaa8a158e7e4bb5d1f0e94ca606":[5,0,0,29,1],
+"group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c":[3,1,1,5],
+"group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c":[5,0,0,29,2],
+"group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca":[3,1,1,10],
+"group__api__types.html#ga9fb5bee0255a52b1b8b8fa1b8620cbca":[5,0,0,29,20],
+"group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb":[3,1,1,9],
+"group__api__types.html#gab4f7e8d204246a3702c6e31a404b0edb":[5,0,0,29,19],
+"group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1":[3,1,1,6],
+"group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1":[5,0,0,29,3],
+"group__api__types.html#structpn__atom__t":[3,1,1,0],
+"group__api__types.html#structpn__bytes__t":[3,1,1,1],
+"group__api__types.html#structpn__rwbytes__t":[3,1,1,2],
+"group__codec.html":[3,2],
+"group__condition.html":[3,0,6],
+"group__condition.html#ga05b0d374d90f11d9ebbf818662569689":[3,0,6,3],
+"group__condition.html#ga05b0d374d90f11d9ebbf818662569689":[5,0,0,2,3],
+"group__condition.html#ga112611a7a4087e050c476a430db2cfb9":[3,0,6,1],
+"group__condition.html#ga112611a7a4087e050c476a430db2cfb9":[5,0,0,2,1],
+"group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5":[3,0,6,0],
+"group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5":[5,0,0,2,0],
+"group__condition.html#ga1dba0d01af7ba6ad7ad6b02bf642a46b":[3,0,6,7],
+"group__condition.html#ga1dba0d01af7ba6ad7ad6b02bf642a46b":[5,0,0,2,7],
+"group__condition.html#ga65d9818487fc61e7ca75a9ec4abc8676":[3,0,6,9],
+"group__condition.html#ga65d9818487fc61e7ca75a9ec4abc8676":[5,0,0,2,9],
+"group__condition.html#ga76c5dbc715c0d72d7dad2126b797eb64":[3,0,6,11],
+"group__condition.html#ga76c5dbc715c0d72d7dad2126b797eb64":[5,0,0,2,11],
+"group__condition.html#ga8e7eacc5be9c2223535bb57950171f0b":[3,0,6,6],
+"group__condition.html#ga8e7eacc5be9c2223535bb57950171f0b":[5,0,0,2,6],
+"group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8":[3,0,6,5],
+"group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8":[5,0,0,2,5],
+"group__condition.html#gab344572fd2d80aa5c52b588129facb27":[3,0,6,4],
+"group__condition.html#gab344572fd2d80aa5c52b588129facb27":[5,0,0,2,4],
+"group__condition.html#gab91d5be5be6a61dc3d9dfaa4e01372b4":[3,0,6,2],
+"group__condition.html#gab91d5be5be6a61dc3d9dfaa4e01372b4":[5,0,0,2,2],
+"group__condition.html#gac798dc9acd131cb47a3e7291efffbc02":[3,0,6,14],
+"group__condition.html#gac798dc9acd131cb47a3e7291efffbc02":[5,0,0,2,14],
+"group__condition.html#gaccab52be69f97d7be2d199b4e1f11380":[3,0,6,8],
+"group__condition.html#gaccab52be69f97d7be2d199b4e1f11380":[5,0,0,2,8],
+"group__condition.html#gad1f52a60bcc855702cfe51e6703625bb":[3,0,6,15],
+"group__condition.html#gad1f52a60bcc855702cfe51e6703625bb":[5,0,0,2,15],
+"group__condition.html#gae495a2885d97a9f167e297efd6974a1e":[3,0,6,13],
+"group__condition.html#gae495a2885d97a9f167e297efd6974a1e":[5,0,0,2,13],
+"group__condition.html#gaefa0da2c1e82f29ddda357e171f5a50a":[3,0,6,10],
+"group__condition.html#gaefa0da2c1e82f29ddda357e171f5a50a":[5,0,0,2,10],
+"group__condition.html#gaf92a380a12c91d4124c22af62318c2e9":[3,0,6,12],
+"group__condition.html#gaf92a380a12c91d4124c22af62318c2e9":[5,0,0,2,12],
+"group__connection.html":[3,0,0],
+"group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e":[3,0,0,11],
+"group__connection.html#ga00cbef1a9f5062a6e1f113fda923f65e":[5,0,0,3,9],
+"group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb":[3,0,0,31],
+"group__connection.html#ga0c3bed8e6764915a137a9daff199ecbb":[5,0,0,3,29],
+"group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa2b":[3,0,0,1],
+"group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa2b":[5,0,0,3,1],
+"group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8":[3,0,0,35],
+"group__connection.html#ga241faafc5a98cf9b91aa919263bd9bd8":[5,0,0,3,33],
+"group__connection.html#ga24a2d5aba432db549257993bfaa761dd":[5,0,0,3,37],
+"group__connection.html#ga24a2d5aba432db549257993bfaa761dd":[3,0,0,39],
+"group__connection.html#ga277d01dc2f87870ee260d43cf40abe13":[3,0,0,19],
+"group__connection.html#ga277d01dc2f87870ee260d43cf40abe13":[5,0,0,3,17],
+"group__connection.html#ga2fd2089e8eaa2a362606498f233ada61":[3,0,0,14],
+"group__connection.html#ga2fd2089e8eaa2a362606498f233ada61":[5,0,0,3,12],
+"group__connection.html#ga32329c4bb3e23607a243cd8100c01264":[5,0,0,3,6],
+"group__connection.html#ga32329c4bb3e23607a243cd8100c01264":[3,0,0,6],
+"group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3":[5,0,0,3,20],
+"group__connection.html#ga3a76135d214e12a0735441c1ba2c28d3":[3,0,0,22],
+"group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c":[3,0,0,30],
+"group__connection.html#ga3ab6a8a556270cff74c39da910a89b5c":[5,0,0,3,28],
+"group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670":[3,0,0,20],
+"group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670":[5,0,0,3,18],
+"group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3":[3,0,0,3],
+"group__connection.html#ga4c35fcb0aacd254d586df8594ee770d3":[5,0,0,3,3],
+"group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07":[3,0,0,16],
+"group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07":[5,0,0,3,14],
+"group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8":[3,0,0,29],
+"group__connection.html#ga5f4b94211f97bbc3bb64642f6f597fe8":[5,0,0,3,27],
+"group__connection.html#ga602c2c870ebed1d9bfe100876909225b":[3,0,0,2],
+"group__connection.html#ga602c2c870ebed1d9bfe100876909225b":[5,0,0,3,2],
+"group__connection.html#ga61e1f6386d18a568da50b998200eb87b":[3,0,0,25],
+"group__connection.html#ga61e1f6386d18a568da50b998200eb87b":[5,0,0,3,23],
+"group__connection.html#ga663c29ee6de4d522ba061224bc6240ad":[3,0,0,15],
+"group__connection.html#ga663c29ee6de4d522ba061224bc6240ad":[5,0,0,3,13],
+"group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3":[3,0,0,7],
+"group__connection.html#ga695af0c2d90d50f4baf403ea60710fa3":[5,0,0,3,7],
+"group__connection.html#ga722d53b6063278fbcab5f814613c70ec":[3,0,0,38],
+"group__connection.html#ga722d53b6063278fbcab5f814613c70ec":[5,0,0,3,36],
+"group__connection.html#ga72a362389b99d8e891bf2e4fb4290754":[3,0,0,24],
+"group__connection.html#ga72a362389b99d8e891bf2e4fb4290754":[5,0,0,3,22],
+"group__connection.html#ga764c602a20457f9aa8862825b6d13a8d":[5,0,0,3,5],
+"group__connection.html#ga764c602a20457f9aa8862825b6d13a8d":[3,0,0,5],
+"group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5":[3,0,0,12],
+"group__connection.html#ga7c88b4833cf81d801b27d00b45d137b5":[5,0,0,3,10],
+"group__connection.html#ga886351d81ff3a977a284a206526c5aff":[3,0,0,9],
+"group__connection.html#ga886351d81ff3a977a284a206526c5aff":[5,0,0,29,11],
+"group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285":[3,0,0,28],
+"group__connection.html#ga8be7fdeb5a229d16e45fa122844fb285":[5,0,0,3,26],
+"group__connection.html#ga9bf90f0f395d26e320293063b70d040f":[3,0,0,37],
+"group__connection.html#ga9bf90f0f395d26e320293063b70d040f":[5,0,0,3,35],
+"group__connection.html#gaa83193a655e32bffc18624acc2c39233":[3,0,0,8],
+"group__connection.html#gaa83193a655e32bffc18624acc2c39233":[5,0,0,29,10],
+"group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d":[3,0,0,10],
+"group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d":[5,0,0,3,8],
+"group__connection.html#gaace04a030192f34747bb1ff3675c58f1":[3,0,0,23],
+"group__connection.html#gaace04a030192f34747bb1ff3675c58f1":[5,0,0,3,21],
+"group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a":[3,0,0,32]
 };

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex1.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex1.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex1.js
index 161381b..5917259 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex1.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex1.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX1 =
 {
-"group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0":[4,0,0,2,19],
-"group__connection.html#gac26de255ed04e73295d6aa973a663142":[2,0,0,36],
-"group__connection.html#gac26de255ed04e73295d6aa973a663142":[4,0,0,2,34],
-"group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a":[2,0,0,26],
-"group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a":[4,0,0,2,24],
-"group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61":[2,0,0,0],
-"group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61":[4,0,0,2,0],
-"group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6":[2,0,0,17],
-"group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6":[4,0,0,2,15],
-"group__connection.html#gad3aad758ccb4690e78d40c1a73567d73":[2,0,0,13],
-"group__connection.html#gad3aad758ccb4690e78d40c1a73567d73":[4,0,0,2,11],
-"group__connection.html#gad8b6c777b525c9da9401e3a770db15da":[2,0,0,18],
-"group__connection.html#gad8b6c777b525c9da9401e3a770db15da":[4,0,0,2,16],
-"group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59":[2,0,0,40],
-"group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59":[4,0,0,2,38],
-"group__connection.html#gad96220f2886c21a4f2eebc9487f53a87":[2,0,0,4],
-"group__connection.html#gad96220f2886c21a4f2eebc9487f53a87":[4,0,0,2,4],
-"group__connection.html#gafb84dd2ef7551ad864be08cb31010d19":[2,0,0,27],
-"group__connection.html#gafb84dd2ef7551ad864be08cb31010d19":[4,0,0,2,25],
-"group__connection__driver.html":[2,3,3],
-"group__connection__driver.html#a274eb4e9f62c87e615e8f1d0041a6f61":[2,3,3,0,0],
-"group__connection__driver.html#a68f8277114ef53d411b76ff3a424f4c5":[2,3,3,0,3],
-"group__connection__driver.html#a98dc9098e6258677bcb7e87d324858ac":[2,3,3,0,2],
-"group__connection__driver.html#aa07ae8b40e8e06ed2e1532c089c4b779":[2,3,3,0,1],
-"group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3":[2,3,3,15],
-"group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3":[4,0,0,3,14],
-"group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5":[2,3,3,17],
-"group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5":[4,0,0,3,16],
-"group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438":[2,3,3,8],
-"group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438":[4,0,0,3,7],
-"group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f":[2,3,3,10],
-"group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f":[4,0,0,3,9],
-"group__connection__driver.html#ga2330d329e295da740ef8d126657470c6":[2,3,3,4],
-"group__connection__driver.html#ga2330d329e295da740ef8d126657470c6":[4,0,0,3,3],
-"group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e":[2,3,3,20],
-"group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e":[4,0,0,3,19],
-"group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4":[2,3,3,19],
-"group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4":[4,0,0,3,18],
-"group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f":[2,3,3,12],
-"group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f":[4,0,0,3,11],
-"group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96":[2,3,3,6],
-"group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96":[4,0,0,3,5],
-"group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23":[2,3,3,11],
-"group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23":[4,0,0,3,10],
-"group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2":[2,3,3,1],
-"group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2":[4,0,0,3,0],
-"group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab":[2,3,3,23],
-"group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab":[4,0,0,3,22],
-"group__connection__driver.html#ga96a6bf8efc2dd7b76734cb2432441333":[2,3,3,7],
-"group__connection__driver.html#ga96a6bf8efc2dd7b76734cb2432441333":[4,0,0,3,6],
-"group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711":[2,3,3,3],
-"group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711":[4,0,0,3,2],
-"group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb":[2,3,3,2],
-"group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb":[4,0,0,3,1],
-"group__connection__driver.html#gaa164510528ce160efddbde2245c438b1":[2,3,3,9],
-"group__connection__driver.html#gaa164510528ce160efddbde2245c438b1":[4,0,0,3,8],
-"group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63":[2,3,3,24],
-"group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63":[4,0,0,3,23],
-"group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb":[2,3,3,16],
-"group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb":[4,0,0,3,15],
-"group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56":[2,3,3,5],
-"group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56":[4,0,0,3,4],
-"group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2":[2,3,3,21],
-"group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2":[4,0,0,3,20],
-"group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf":[2,3,3,25],
-"group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf":[4,0,0,3,24],
-"group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e":[2,3,3,22],
-"group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e":[4,0,0,3,21],
-"group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7":[2,3,3,18],
-"group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7":[4,0,0,3,17],
-"group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243":[2,3,3,13],
-"group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243":[4,0,0,3,12],
-"group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce":[2,3,3,14],
-"group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce":[4,0,0,3,13],
-"group__connection__driver.html#structpn__connection__driver__t":[2,3,3,0],
-"group__core.html":[2,0],
-"group__data.html":[2,2,0],
-"group__data.html#ga00126d993e32a202c34f912d57b8e5ce":[2,2,0,42],
-"group__data.html#ga00126d993e32a202c34f912d57b8e5ce":[4,0,0,0,44],
-"group__data.html#ga0199029f44d9c86e469c15bef51ceea2":[2,2,0,36],
-"group__data.html#ga0199029f44d9c86e469c15bef51ceea2":[4,0,0,0,38],
-"group__data.html#ga0a98b8f17784460034c240ed4b6b47d7":[2,2,0,74],
-"group__data.html#ga0a98b8f17784460034c240ed4b6b47d7":[4,0,0,0,76],
-"group__data.html#ga1093449b80357dabf3f70a4bf804f4f7":[2,2,0,10],
-"group__data.html#ga1093449b80357dabf3f70a4bf804f4f7":[4,0,0,0,12],
-"group__data.html#ga11c026fb5ec5e8620258f52ed86229b4":[2,2,0,48],
-"group__data.html#ga11c026fb5ec5e8620258f52ed86229b4":[4,0,0,0,50],
-"group__data.html#ga121070d2c21ef594f1cfe4083677f1a2":[2,2,0,35],
-"group__data.html#ga121070d2c21ef594f1cfe4083677f1a2":[4,0,0,0,37],
-"group__data.html#ga122e7f20f958d51900675d37d80bd37e":[2,2,0,47],
-"group__data.html#ga122e7f20f958d51900675d37d80bd37e":[4,0,0,0,49],
-"group__data.html#ga148ae972de23a6694cd18a510eee4856":[2,2,0,6],
-"group__data.html#ga148ae972de23a6694cd18a510eee4856":[4,0,0,0,8],
-"group__data.html#ga182347d1d444bf6290b39239c4c13d0f":[2,2,0,25],
-"group__data.html#ga182347d1d444bf6290b39239c4c13d0f":[4,0,0,0,27],
-"group__data.html#ga1fce9c3194a700eb99552c71651d28fc":[2,2,0,34],
-"group__data.html#ga1fce9c3194a700eb99552c71651d28fc":[4,0,0,0,36],
-"group__data.html#ga20dda5db37c55c12b28e428c311b79da":[2,2,0,20],
-"group__data.html#ga20dda5db37c55c12b28e428c311b79da":[4,0,0,0,22],
-"group__data.html#ga254abc4df02a5c2e87fd3bdac2e14846":[2,2,0,54],
-"group__data.html#ga254abc4df02a5c2e87fd3bdac2e14846":[4,0,0,0,56],
-"group__data.html#ga26d61fd9b512c322344d410384202005":[2,2,0,7],
-"group__data.html#ga26d61fd9b512c322344d410384202005":[4,0,0,0,9],
-"group__data.html#ga2843b707e33437a8673e8b904c8faea1":[2,2,0,12],
-"group__data.html#ga2843b707e33437a8673e8b904c8faea1":[4,0,0,0,14],
-"group__data.html#ga2c02eee58084ba9b77a37c086e195802":[2,2,0,2],
-"group__data.html#ga2c02eee58084ba9b77a37c086e195802":[4,0,0,0,4],
-"group__data.html#ga3af18fc419995766f83a4b4ac07c31ce":[2,2,0,44],
-"group__data.html#ga3af18fc419995766f83a4b4ac07c31ce":[4,0,0,0,46],
-"group__data.html#ga3bdeb99d1275d7fe06a46818467d03d9":[2,2,0,65],
-"group__data.html#ga3bdeb99d1275d7fe06a46818467d03d9":[4,0,0,0,67],
-"group__data.html#ga3c64a188867ebb19c8d4e3908e6f8e20":[2,2,0,70],
-"group__data.html#ga3c64a188867ebb19c8d4e3908e6f8e20":[4,0,0,0,72],
-"group__data.html#ga49df9ede673853123d84861c169d6113":[2,2,0,24],
-"group__data.html#ga49df9ede673853123d84861c169d6113":[4,0,0,0,26],
-"group__data.html#ga4a35f7001de91101d78143e4e98e6556":[2,2,0,23],
-"group__data.html#ga4a35f7001de91101d78143e4e98e6556":[4,0,0,0,25],
-"group__data.html#ga4c77c7a884bbd9a757b31060962d8543":[2,2,0,19],
-"group__data.html#ga4c77c7a884bbd9a757b31060962d8543":[4,0,0,0,21],
-"group__data.html#ga4f9ccacd002e89127b278703a6c680da":[2,2,0,57],
-"group__data.html#ga4f9ccacd002e89127b278703a6c680da":[4,0,0,0,59],
-"group__data.html#ga502e9571b513b58bce5a5ae442951400":[2,2,0,80],
-"group__data.html#ga502e9571b513b58bce5a5ae442951400":[4,0,0,0,82],
-"group__data.html#ga549ee35ecd73ac55e9e8aa196a6ba2ec":[2,2,0,28],
-"group__data.html#ga549ee35ecd73ac55e9e8aa196a6ba2ec":[4,0,0,0,30],
-"group__data.html#ga5502724bcde68615bc47e09a3335b527":[2,2,0,15],
-"group__data.html#ga5502724bcde68615bc47e09a3335b527":[4,0,0,0,17],
-"group__data.html#ga5ba3f8eb5a972b9a579bc5af9e7fbde2":[2,2,0,67],
-"group__data.html#ga5ba3f8eb5a972b9a579bc5af9e7fbde2":[4,0,0,0,69],
-"group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf":[2,2,0,0],
-"group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf":[4,0,0,0,0],
-"group__data.html#ga5d876ccb1d65d46af7db461d4415baab":[2,2,0,39],
-"group__data.html#ga5d876ccb1d65d46af7db461d4415baab":[4,0,0,0,41],
-"group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee":[2,2,0,41],
-"group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee":[4,0,0,0,43],
-"group__data.html#ga61162ca933ab6b957270f27910981eef":[2,2,0,78],
-"group__data.html#ga61162ca933ab6b957270f27910981eef":[4,0,0,0,80],
-"group__data.html#ga61944d632d27ffc1c0d6348f62bfec4e":[2,2,0,38],
-"group__data.html#ga61944d632d27ffc1c0d6348f62bfec4e":[4,0,0,0,40],
-"group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48":[2,2,0,11],
-"group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48":[4,0,0,0,13],
-"group__data.html#ga68e94dfa5d7ab568425c4a6587bac1db":[2,2,0,3],
-"group__data.html#ga68e94dfa5d7ab568425c4a6587bac1db":[4,0,0,0,5],
-"group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016":[2,2,0,29],
-"group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016":[4,0,0,0,31],
-"group__data.html#ga74430b712be334a05861cfd5e9b312b9":[2,2,0,17],
-"group__data.html#ga74430b712be334a05861cfd5e9b312b9":[4,0,0,0,19],
-"group__data.html#ga7490c3ee3444557fba3c7ad92e0f0d77":[2,2,0,21],
-"group__data.html#ga7490c3ee3444557fba3c7ad92e0f0d77":[4,0,0,0,23],
-"group__data.html#ga7582b8fd0ecdf0368a600b9c4f22faa8":[2,2,0,52],
-"group__data.html#ga7582b8fd0ecdf0368a600b9c4f22faa8":[4,0,0,0,54],
-"group__data.html#ga7611c1394e80b5166b8b8647659f97e6":[2,2,0,5],
-"group__data.html#ga7611c1394e80b5166b8b8647659f97e6":[4,0,0,0,7],
-"group__data.html#ga7672e15a4925bb14bebb79bc8206d392":[2,2,0,37],
-"group__data.html#ga7672e15a4925bb14bebb79bc8206d392":[4,0,0,0,39],
-"group__data.html#ga8d813db46df4e635b1ab2c400403560c":[2,2,0,60],
-"group__data.html#ga8d813db46df4e635b1ab2c400403560c":[4,0,0,0,62],
-"group__data.html#ga90f32862f64d65091d6fb1e7380a672b":[2,2,0,32],
-"group__data.html#ga90f32862f64d65091d6fb1e7380a672b":[4,0,0,0,34],
-"group__data.html#ga92247a44abd6b6d01d9216d5b1e2e781":[2,2,0,79],
-"group__data.html#ga92247a44abd6b6d01d9216d5b1e2e781":[4,0,0,0,81],
-"group__data.html#ga926c8732c66f38f3b9578d50af30f2ff":[2,2,0,43],
-"group__data.html#ga926c8732c66f38f3b9578d50af30f2ff":[4,0,0,0,45],
-"group__data.html#ga9541c1ee071c7d0b38805e1b01672ccc":[2,2,0,56],
-"group__data.html#ga9541c1ee071c7d0b38805e1b01672ccc":[4,0,0,0,58],
-"group__data.html#ga95c0c0750831ee3b8454af8bc51a787b":[2,2,0,18],
-"group__data.html#ga95c0c0750831ee3b8454af8bc51a787b":[4,0,0,0,20],
-"group__data.html#ga96c9a1c5f179036cd9513c50c0ac57de":[2,2,0,8],
-"group__data.html#ga96c9a1c5f179036cd9513c50c0ac57de":[4,0,0,0,10],
-"group__data.html#ga97c448c037e34404df782c82d77b2bc3":[2,2,0,63],
-"group__data.html#ga97c448c037e34404df782c82d77b2bc3":[4,0,0,0,65],
-"group__data.html#ga9a048cfd78ca76604b667d170eac0136":[2,2,0,75],
-"group__data.html#ga9a048cfd78ca76604b667d170eac0136":[4,0,0,0,77],
-"group__data.html#ga9b5888f354a3a3b084c74186ed59284c":[2,2,0,26],
-"group__data.html#ga9b5888f354a3a3b084c74186ed59284c":[4,0,0,0,28],
-"group__data.html#ga9deeb028b90df8bfa3cad7928348b46b":[2,2,0,58],
-"group__data.html#ga9deeb028b90df8bfa3cad7928348b46b":[4,0,0,0,60],
-"group__data.html#ga9ee214dd19c845f76e29651682732e16":[2,2,0,9],
-"group__data.html#ga9ee214dd19c845f76e29651682732e16":[4,0,0,0,11],
-"group__data.html#gaa63068cf2ed94f05b20f6c49c908a2c6":[2,2,0,14],
-"group__data.html#gaa63068cf2ed94f05b20f6c49c908a2c6":[4,0,0,0,16],
-"group__data.html#gaa756be79ecfab947ecea57ed8a9089f7":[2,2,0,53],
-"group__data.html#gaa756be79ecfab947ecea57ed8a9089f7":[4,0,0,0,55],
-"group__data.html#gaac08905c5bfb2371951914e0fb2793b9":[2,2,0,76],
-"group__data.html#gaac08905c5bfb2371951914e0fb2793b9":[4,0,0,0,78],
-"group__data.html#gaaf46509788aba824bb16343b566f1929":[2,2,0,13],
-"group__data.html#gaaf46509788aba824bb16343b566f1929":[4,0,0,0,15],
-"group__data.html#gab0f8eefe5f89362ffe186a092044d936":[2,2,0,46],
-"group__data.html#gab0f8eefe5f89362ffe186a092044d936":[4,0,0,0,48],
-"group__data.html#gab230cca5089c6c28c4c12d507513fde9":[2,2,0,27],
-"group__data.html#gab230cca5089c6c28c4c12d507513fde9":[4,0,0,0,29],
-"group__data.html#gab3f699c30da99e02d13f773988e3849e":[2,2,0,77],
-"group__data.html#gab3f699c30da99e02d13f773988e3849e":[4,0,0,0,79],
-"group__data.html#gabba00ce3862818acd8ca91c2a8af348b":[2,2,0,50],
-"group__data.html#gabba00ce3862818acd8ca91c2a8af348b":[4,0,0,0,52],
-"group__data.html#gabdbfa1e913c490d3b1ad6ca169910482":[2,2,0,64],
-"group__data.html#gabdbfa1e913c490d3b1ad6ca169910482":[4,0,0,0,66],
-"group__data.html#gabf41ef79c9a4f7e3fd673b0999e63a41":[2,2,0,62],
-"group__data.html#gabf41ef79c9a4f7e3fd673b0999e63a41":[4,0,0,0,64],
-"group__data.html#gac21c6f1c517ac486e2923baa3d0c5db4":[2,2,0,1],
-"group__data.html#gac21c6f1c517ac486e2923baa3d0c5db4":[4,0,0,0,3],
-"group__data.html#gac5d5c6e6bf24597caf63d35b1755e646":[2,2,0,72],
-"group__data.html#gac5d5c6e6bf24597caf63d35b1755e646":[4,0,0,0,74],
-"group__data.html#gac8cf4d1cb60c3313f4d61f45bceda5ba":[2,2,0,61],
-"group__data.html#gac8cf4d1cb60c3313f4d61f45bceda5ba":[4,0,0,0,63],
-"group__data.html#gacb2c0b2c56d587ee354aaa0f21f2c9b1":[2,2,0,33],
-"group__data.html#gacb2c0b2c56d587ee354aaa0f21f2c9b1":[4,0,0,0,35],
-"group__data.html#gacc4bf3683c8234a94bca8af3ced8c875":[2,2,0,31],
-"group__data.html#gacc4bf3683c8234a94bca8af3ced8c875":[4,0,0,0,33],
-"group__data.html#gad03a049653bec28d20dc7587f7e544de":[2,2,0,71],
-"group__data.html#gad03a049653bec28d20dc7587f7e544de":[4,0,0,0,73],
-"group__data.html#gad406a4cf5bbc22b47cae78954b44c9ef":[2,2,0,30],
-"group__data.html#gad406a4cf5bbc22b47cae78954b44c9ef":[4,0,0,0,32],
-"group__data.html#gad7fac25ba5589ff0374442cf7ecbbd9c":[2,2,0,49],
-"group__data.html#gad7fac25ba5589ff0374442cf7ecbbd9c":[4,0,0,0,51],
-"group__data.html#gada171f4740e6a1132b4d4b9c0aea645c":[2,2,0,4],
-"group__data.html#gada171f4740e6a1132b4d4b9c0aea645c":[4,0,0,0,6],
-"group__data.html#gadbd4c895a1e10266d20898996ce53bc0":[2,2,0,45],
-"group__data.html#gadbd4c895a1e10266d20898996ce53bc0":[4,0,0,0,47],
-"group__data.html#gae71bfb440cc4f0b15fe958bf55a3f6af":[2,2,0,16],
-"group__data.html#gae71bfb440cc4f0b15fe958bf55a3f6af":[4,0,0,0,18],
-"group__data.html#gaeab50c7bd297665714861cfcb8f51124":[2,2,0,51],
-"group__data.html#gaeab50c7bd297665714861cfcb8f51124":[4,0,0,0,53],
-"group__data.html#gaeb8b424245ca352fb63dce8ca03cd8da":[2,2,0,66],
-"group__data.html#gaeb8b424245ca352fb63dce8ca03cd8da":[4,0,0,0,68],
-"group__data.html#gaeddd7cf9d968e81ebe72831330e7cd21":[2,2,0,40],
-"group__data.html#gaeddd7cf9d968e81ebe72831330e7cd21":[4,0,0,0,42],
-"group__data.html#gaee6e7a4f78d202cc81657e3976fd68ae":[2,2,0,68],
-"group__data.html#gaee6e7a4f78d202cc81657e3976fd68ae":[4,0,0,0,70],
-"group__data.html#gaef4aa1c6873eb59a46ccaf76c492826f":[2,2,0,59],
-"group__data.html#gaef4aa1c6873eb59a46ccaf76c492826f":[4,0,0,0,61],
-"group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332":[2,2,0,73],
-"group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332":[4,0,0,0,75],
-"group__data.html#gaf76476c18ae09c520a3ae01eaa62cc92":[2,2,0,22],
-"group__data.html#gaf76476c18ae09c520a3ae01eaa62cc92":[4,0,0,0,24],
-"group__data.html#gafccb5008960eb8dc757cb7f9941e5013":[2,2,0,69],
-"group__data.html#gafccb5008960eb8dc757cb7f9941e5013":[4,0,0,0,71],
-"group__data.html#gafe894205eaba01d1caf8ee2aa68ed55c":[2,2,0,55],
-"group__data.html#gafe894205eaba01d1caf8ee2aa68ed55c":[4,0,0,0,57],
-"group__delivery.html":[2,0,5],
-"group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3":[2,0,5,5],
-"group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3":[4,0,0,4,0],
-"group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb":[2,0,5,31],
-"group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb":[4,0,0,4,24],
-"group__delivery.html#ga102eb1d46ff8fbed816d5c619e5fa52f":[4,0,0,5,11],
-"group__delivery.html#ga102eb1d46ff8fbed816d5c619e5fa52f":[2,0,5,40],
-"group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35":[2,0,5,24],
-"group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35":[4,0,0,4,17],
-"group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40":[2,0,5,20],
-"group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40":[4,0,0,4,13]
+"group__connection.html#gabb5b585ee8bae0e88d2b42b87772082a":[5,0,0,3,30],
+"group__connection.html#gabc8d505108a850837a0d2fb204875390":[3,0,0,34],
+"group__connection.html#gabc8d505108a850837a0d2fb204875390":[5,0,0,3,32],
+"group__connection.html#gabf25d7b763951b4a9c856536d6db0600":[3,0,0,33],
+"group__connection.html#gabf25d7b763951b4a9c856536d6db0600":[5,0,0,3,31],
+"group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0":[5,0,0,3,19],
+"group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0":[3,0,0,21],
+"group__connection.html#gac26de255ed04e73295d6aa973a663142":[3,0,0,36],
+"group__connection.html#gac26de255ed04e73295d6aa973a663142":[5,0,0,3,34],
+"group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a":[3,0,0,26],
+"group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a":[5,0,0,3,24],
+"group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61":[3,0,0,0],
+"group__connection.html#gac83dd8123b992813be86fe0f7eaf8f61":[5,0,0,3,0],
+"group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6":[3,0,0,17],
+"group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6":[5,0,0,3,15],
+"group__connection.html#gad3aad758ccb4690e78d40c1a73567d73":[3,0,0,13],
+"group__connection.html#gad3aad758ccb4690e78d40c1a73567d73":[5,0,0,3,11],
+"group__connection.html#gad8b6c777b525c9da9401e3a770db15da":[3,0,0,18],
+"group__connection.html#gad8b6c777b525c9da9401e3a770db15da":[5,0,0,3,16],
+"group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59":[3,0,0,40],
+"group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59":[5,0,0,3,38],
+"group__connection.html#gad96220f2886c21a4f2eebc9487f53a87":[3,0,0,4],
+"group__connection.html#gad96220f2886c21a4f2eebc9487f53a87":[5,0,0,3,4],
+"group__connection.html#gafb84dd2ef7551ad864be08cb31010d19":[3,0,0,27],
+"group__connection.html#gafb84dd2ef7551ad864be08cb31010d19":[5,0,0,3,25],
+"group__connection__driver.html":[3,3,3],
+"group__connection__driver.html#a274eb4e9f62c87e615e8f1d0041a6f61":[3,3,3,0,0],
+"group__connection__driver.html#a68f8277114ef53d411b76ff3a424f4c5":[3,3,3,0,3],
+"group__connection__driver.html#a98dc9098e6258677bcb7e87d324858ac":[3,3,3,0,2],
+"group__connection__driver.html#aa07ae8b40e8e06ed2e1532c089c4b779":[3,3,3,0,1],
+"group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3":[3,3,3,15],
+"group__connection__driver.html#ga001b2f3c1bfe4d24d53b93d79dccbfe3":[5,0,0,4,14],
+"group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5":[3,3,3,17],
+"group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5":[5,0,0,4,16],
+"group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438":[3,3,3,8],
+"group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438":[5,0,0,4,7],
+"group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f":[3,3,3,10],
+"group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f":[5,0,0,4,9],
+"group__connection__driver.html#ga2330d329e295da740ef8d126657470c6":[3,3,3,4],
+"group__connection__driver.html#ga2330d329e295da740ef8d126657470c6":[5,0,0,4,3],
+"group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e":[3,3,3,20],
+"group__connection__driver.html#ga373eb1f632468582d025f5d6acf9655e":[5,0,0,4,19],
+"group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4":[3,3,3,19],
+"group__connection__driver.html#ga38f56836858b2d4a04ab961f650950d4":[5,0,0,4,18],
+"group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f":[3,3,3,12],
+"group__connection__driver.html#ga3e5795e14572eec632231fe9f916ca5f":[5,0,0,4,11],
+"group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96":[3,3,3,6],
+"group__connection__driver.html#ga3e8959d7897cd9415f687981c1d94c96":[5,0,0,4,5],
+"group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23":[3,3,3,11],
+"group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23":[5,0,0,4,10],
+"group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2":[3,3,3,1],
+"group__connection__driver.html#ga56e55c7d0343529b7fb3002b930a36b2":[5,0,0,4,0],
+"group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab":[3,3,3,24],
+"group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab":[5,0,0,4,23],
+"group__connection__driver.html#ga96a6bf8efc2dd7b76734cb2432441333":[3,3,3,7],
+"group__connection__driver.html#ga96a6bf8efc2dd7b76734cb2432441333":[5,0,0,4,6],
+"group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711":[3,3,3,3],
+"group__connection__driver.html#ga9793522a25c9741e8d17a570a47e9711":[5,0,0,4,2],
+"group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb":[3,3,3,2],
+"group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb":[5,0,0,4,1],
+"group__connection__driver.html#gaa164510528ce160efddbde2245c438b1":[3,3,3,9],
+"group__connection__driver.html#gaa164510528ce160efddbde2245c438b1":[5,0,0,4,8],
+"group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0":[3,3,3,26],
+"group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0":[5,0,0,4,25],
+"group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63":[3,3,3,25],
+"group__connection__driver.html#gabf97a6a0b608fd096fcaa4f2692c2c63":[5,0,0,4,24],
+"group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb":[3,3,3,16],
+"group__connection__driver.html#gad0c98415e0105efb71e8c1a8c4c1e5fb":[5,0,0,4,15],
+"group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56":[3,3,3,5],
+"group__connection__driver.html#gad2bdef0f5abe7cf593afcee237c6af56":[5,0,0,4,4],
+"group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2":[3,3,3,21],
+"group__connection__driver.html#gad774f90adceaf86748a0ae781f66daf2":[5,0,0,4,20],
+"group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf":[3,3,3,22],
+"group__connection__driver.html#gada5c75a658ae2814f253a91723be9baf":[5,0,0,4,21],
+"group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e":[3,3,3,23],
+"group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e":[5,0,0,4,22],
+"group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7":[3,3,3,18],
+"group__connection__driver.html#gae51f2124706bb1674e2c623a2dc62da7":[5,0,0,4,17],
+"group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243":[3,3,3,13],
+"group__connection__driver.html#gaead42b6a9356214d9e2bb591af009243":[5,0,0,4,12],
+"group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce":[3,3,3,14],
+"group__connection__driver.html#gafdca1cd72d6da760d3df7981085b36ce":[5,0,0,4,13],
+"group__connection__driver.html#structpn__connection__driver__t":[3,3,3,0],
+"group__core.html":[3,0],
+"group__data.html":[3,2,0],
+"group__data.html#ga00126d993e32a202c34f912d57b8e5ce":[3,2,0,42],
+"group__data.html#ga00126d993e32a202c34f912d57b8e5ce":[5,0,0,1,44],
+"group__data.html#ga0199029f44d9c86e469c15bef51ceea2":[3,2,0,36],
+"group__data.html#ga0199029f44d9c86e469c15bef51ceea2":[5,0,0,1,38],
+"group__data.html#ga0a98b8f17784460034c240ed4b6b47d7":[3,2,0,74],
+"group__data.html#ga0a98b8f17784460034c240ed4b6b47d7":[5,0,0,1,76],
+"group__data.html#ga1093449b80357dabf3f70a4bf804f4f7":[3,2,0,10],
+"group__data.html#ga1093449b80357dabf3f70a4bf804f4f7":[5,0,0,1,12],
+"group__data.html#ga11c026fb5ec5e8620258f52ed86229b4":[3,2,0,48],
+"group__data.html#ga11c026fb5ec5e8620258f52ed86229b4":[5,0,0,1,50],
+"group__data.html#ga121070d2c21ef594f1cfe4083677f1a2":[3,2,0,35],
+"group__data.html#ga121070d2c21ef594f1cfe4083677f1a2":[5,0,0,1,37],
+"group__data.html#ga122e7f20f958d51900675d37d80bd37e":[3,2,0,47],
+"group__data.html#ga122e7f20f958d51900675d37d80bd37e":[5,0,0,1,49],
+"group__data.html#ga148ae972de23a6694cd18a510eee4856":[3,2,0,6],
+"group__data.html#ga148ae972de23a6694cd18a510eee4856":[5,0,0,1,8],
+"group__data.html#ga182347d1d444bf6290b39239c4c13d0f":[3,2,0,25],
+"group__data.html#ga182347d1d444bf6290b39239c4c13d0f":[5,0,0,1,27],
+"group__data.html#ga1fce9c3194a700eb99552c71651d28fc":[3,2,0,34],
+"group__data.html#ga1fce9c3194a700eb99552c71651d28fc":[5,0,0,1,36],
+"group__data.html#ga20dda5db37c55c12b28e428c311b79da":[3,2,0,20],
+"group__data.html#ga20dda5db37c55c12b28e428c311b79da":[5,0,0,1,22],
+"group__data.html#ga254abc4df02a5c2e87fd3bdac2e14846":[3,2,0,54],
+"group__data.html#ga254abc4df02a5c2e87fd3bdac2e14846":[5,0,0,1,56],
+"group__data.html#ga26d61fd9b512c322344d410384202005":[3,2,0,7],
+"group__data.html#ga26d61fd9b512c322344d410384202005":[5,0,0,1,9],
+"group__data.html#ga2843b707e33437a8673e8b904c8faea1":[3,2,0,12],
+"group__data.html#ga2843b707e33437a8673e8b904c8faea1":[5,0,0,1,14],
+"group__data.html#ga2c02eee58084ba9b77a37c086e195802":[3,2,0,2],
+"group__data.html#ga2c02eee58084ba9b77a37c086e195802":[5,0,0,1,4],
+"group__data.html#ga3af18fc419995766f83a4b4ac07c31ce":[3,2,0,44],
+"group__data.html#ga3af18fc419995766f83a4b4ac07c31ce":[5,0,0,1,46],
+"group__data.html#ga3bdeb99d1275d7fe06a46818467d03d9":[3,2,0,65],
+"group__data.html#ga3bdeb99d1275d7fe06a46818467d03d9":[5,0,0,1,67],
+"group__data.html#ga3c64a188867ebb19c8d4e3908e6f8e20":[3,2,0,70],
+"group__data.html#ga3c64a188867ebb19c8d4e3908e6f8e20":[5,0,0,1,72],
+"group__data.html#ga49df9ede673853123d84861c169d6113":[3,2,0,24],
+"group__data.html#ga49df9ede673853123d84861c169d6113":[5,0,0,1,26],
+"group__data.html#ga4a35f7001de91101d78143e4e98e6556":[3,2,0,23],
+"group__data.html#ga4a35f7001de91101d78143e4e98e6556":[5,0,0,1,25],
+"group__data.html#ga4c77c7a884bbd9a757b31060962d8543":[3,2,0,19],
+"group__data.html#ga4c77c7a884bbd9a757b31060962d8543":[5,0,0,1,21],
+"group__data.html#ga4f9ccacd002e89127b278703a6c680da":[3,2,0,57],
+"group__data.html#ga4f9ccacd002e89127b278703a6c680da":[5,0,0,1,59],
+"group__data.html#ga502e9571b513b58bce5a5ae442951400":[3,2,0,80],
+"group__data.html#ga502e9571b513b58bce5a5ae442951400":[5,0,0,1,82],
+"group__data.html#ga549ee35ecd73ac55e9e8aa196a6ba2ec":[3,2,0,28],
+"group__data.html#ga549ee35ecd73ac55e9e8aa196a6ba2ec":[5,0,0,1,30],
+"group__data.html#ga5502724bcde68615bc47e09a3335b527":[3,2,0,15],
+"group__data.html#ga5502724bcde68615bc47e09a3335b527":[5,0,0,1,17],
+"group__data.html#ga5ba3f8eb5a972b9a579bc5af9e7fbde2":[3,2,0,67],
+"group__data.html#ga5ba3f8eb5a972b9a579bc5af9e7fbde2":[5,0,0,1,69],
+"group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf":[3,2,0,0],
+"group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf":[5,0,0,1,0],
+"group__data.html#ga5d876ccb1d65d46af7db461d4415baab":[3,2,0,39],
+"group__data.html#ga5d876ccb1d65d46af7db461d4415baab":[5,0,0,1,41],
+"group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee":[3,2,0,41],
+"group__data.html#ga5dc9c9c7db2018d12753767c075cc6ee":[5,0,0,1,43],
+"group__data.html#ga61162ca933ab6b957270f27910981eef":[3,2,0,78],
+"group__data.html#ga61162ca933ab6b957270f27910981eef":[5,0,0,1,80],
+"group__data.html#ga61944d632d27ffc1c0d6348f62bfec4e":[3,2,0,38],
+"group__data.html#ga61944d632d27ffc1c0d6348f62bfec4e":[5,0,0,1,40],
+"group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48":[3,2,0,11],
+"group__data.html#ga67a656cbdbf0a47a223ff1c8507ecf48":[5,0,0,1,13],
+"group__data.html#ga68e94dfa5d7ab568425c4a6587bac1db":[3,2,0,3],
+"group__data.html#ga68e94dfa5d7ab568425c4a6587bac1db":[5,0,0,1,5],
+"group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016":[3,2,0,29],
+"group__data.html#ga6cfb9e64b87f8d90a5b4237ca016a016":[5,0,0,1,31],
+"group__data.html#ga74430b712be334a05861cfd5e9b312b9":[3,2,0,17],
+"group__data.html#ga74430b712be334a05861cfd5e9b312b9":[5,0,0,1,19],
+"group__data.html#ga7490c3ee3444557fba3c7ad92e0f0d77":[3,2,0,21],
+"group__data.html#ga7490c3ee3444557fba3c7ad92e0f0d77":[5,0,0,1,23],
+"group__data.html#ga7582b8fd0ecdf0368a600b9c4f22faa8":[3,2,0,52],
+"group__data.html#ga7582b8fd0ecdf0368a600b9c4f22faa8":[5,0,0,1,54],
+"group__data.html#ga7611c1394e80b5166b8b8647659f97e6":[3,2,0,5],
+"group__data.html#ga7611c1394e80b5166b8b8647659f97e6":[5,0,0,1,7],
+"group__data.html#ga7672e15a4925bb14bebb79bc8206d392":[3,2,0,37],
+"group__data.html#ga7672e15a4925bb14bebb79bc8206d392":[5,0,0,1,39],
+"group__data.html#ga8d813db46df4e635b1ab2c400403560c":[3,2,0,60],
+"group__data.html#ga8d813db46df4e635b1ab2c400403560c":[5,0,0,1,62],
+"group__data.html#ga90f32862f64d65091d6fb1e7380a672b":[3,2,0,32],
+"group__data.html#ga90f32862f64d65091d6fb1e7380a672b":[5,0,0,1,34],
+"group__data.html#ga92247a44abd6b6d01d9216d5b1e2e781":[3,2,0,79],
+"group__data.html#ga92247a44abd6b6d01d9216d5b1e2e781":[5,0,0,1,81],
+"group__data.html#ga926c8732c66f38f3b9578d50af30f2ff":[3,2,0,43],
+"group__data.html#ga926c8732c66f38f3b9578d50af30f2ff":[5,0,0,1,45],
+"group__data.html#ga9541c1ee071c7d0b38805e1b01672ccc":[3,2,0,56],
+"group__data.html#ga9541c1ee071c7d0b38805e1b01672ccc":[5,0,0,1,58],
+"group__data.html#ga95c0c0750831ee3b8454af8bc51a787b":[3,2,0,18],
+"group__data.html#ga95c0c0750831ee3b8454af8bc51a787b":[5,0,0,1,20],
+"group__data.html#ga96c9a1c5f179036cd9513c50c0ac57de":[3,2,0,8],
+"group__data.html#ga96c9a1c5f179036cd9513c50c0ac57de":[5,0,0,1,10],
+"group__data.html#ga97c448c037e34404df782c82d77b2bc3":[3,2,0,63],
+"group__data.html#ga97c448c037e34404df782c82d77b2bc3":[5,0,0,1,65],
+"group__data.html#ga9a048cfd78ca76604b667d170eac0136":[3,2,0,75],
+"group__data.html#ga9a048cfd78ca76604b667d170eac0136":[5,0,0,1,77],
+"group__data.html#ga9b5888f354a3a3b084c74186ed59284c":[3,2,0,26],
+"group__data.html#ga9b5888f354a3a3b084c74186ed59284c":[5,0,0,1,28],
+"group__data.html#ga9deeb028b90df8bfa3cad7928348b46b":[3,2,0,58],
+"group__data.html#ga9deeb028b90df8bfa3cad7928348b46b":[5,0,0,1,60],
+"group__data.html#ga9ee214dd19c845f76e29651682732e16":[3,2,0,9],
+"group__data.html#ga9ee214dd19c845f76e29651682732e16":[5,0,0,1,11],
+"group__data.html#gaa63068cf2ed94f05b20f6c49c908a2c6":[3,2,0,14],
+"group__data.html#gaa63068cf2ed94f05b20f6c49c908a2c6":[5,0,0,1,16],
+"group__data.html#gaa756be79ecfab947ecea57ed8a9089f7":[3,2,0,53],
+"group__data.html#gaa756be79ecfab947ecea57ed8a9089f7":[5,0,0,1,55],
+"group__data.html#gaac08905c5bfb2371951914e0fb2793b9":[3,2,0,76],
+"group__data.html#gaac08905c5bfb2371951914e0fb2793b9":[5,0,0,1,78],
+"group__data.html#gaaf46509788aba824bb16343b566f1929":[3,2,0,13],
+"group__data.html#gaaf46509788aba824bb16343b566f1929":[5,0,0,1,15],
+"group__data.html#gab0f8eefe5f89362ffe186a092044d936":[3,2,0,46],
+"group__data.html#gab0f8eefe5f89362ffe186a092044d936":[5,0,0,1,48],
+"group__data.html#gab230cca5089c6c28c4c12d507513fde9":[3,2,0,27],
+"group__data.html#gab230cca5089c6c28c4c12d507513fde9":[5,0,0,1,29],
+"group__data.html#gab3f699c30da99e02d13f773988e3849e":[3,2,0,77],
+"group__data.html#gab3f699c30da99e02d13f773988e3849e":[5,0,0,1,79],
+"group__data.html#gabba00ce3862818acd8ca91c2a8af348b":[3,2,0,50],
+"group__data.html#gabba00ce3862818acd8ca91c2a8af348b":[5,0,0,1,52],
+"group__data.html#gabdbfa1e913c490d3b1ad6ca169910482":[3,2,0,64],
+"group__data.html#gabdbfa1e913c490d3b1ad6ca169910482":[5,0,0,1,66],
+"group__data.html#gabf41ef79c9a4f7e3fd673b0999e63a41":[3,2,0,62],
+"group__data.html#gabf41ef79c9a4f7e3fd673b0999e63a41":[5,0,0,1,64],
+"group__data.html#gac21c6f1c517ac486e2923baa3d0c5db4":[3,2,0,1],
+"group__data.html#gac21c6f1c517ac486e2923baa3d0c5db4":[5,0,0,1,3],
+"group__data.html#gac5d5c6e6bf24597caf63d35b1755e646":[3,2,0,72],
+"group__data.html#gac5d5c6e6bf24597caf63d35b1755e646":[5,0,0,1,74],
+"group__data.html#gac8cf4d1cb60c3313f4d61f45bceda5ba":[3,2,0,61],
+"group__data.html#gac8cf4d1cb60c3313f4d61f45bceda5ba":[5,0,0,1,63],
+"group__data.html#gacb2c0b2c56d587ee354aaa0f21f2c9b1":[3,2,0,33],
+"group__data.html#gacb2c0b2c56d587ee354aaa0f21f2c9b1":[5,0,0,1,35],
+"group__data.html#gacc4bf3683c8234a94bca8af3ced8c875":[3,2,0,31],
+"group__data.html#gacc4bf3683c8234a94bca8af3ced8c875":[5,0,0,1,33],
+"group__data.html#gad03a049653bec28d20dc7587f7e544de":[3,2,0,71],
+"group__data.html#gad03a049653bec28d20dc7587f7e544de":[5,0,0,1,73],
+"group__data.html#gad406a4cf5bbc22b47cae78954b44c9ef":[3,2,0,30],
+"group__data.html#gad406a4cf5bbc22b47cae78954b44c9ef":[5,0,0,1,32],
+"group__data.html#gad7fac25ba5589ff0374442cf7ecbbd9c":[3,2,0,49],
+"group__data.html#gad7fac25ba5589ff0374442cf7ecbbd9c":[5,0,0,1,51],
+"group__data.html#gada171f4740e6a1132b4d4b9c0aea645c":[3,2,0,4],
+"group__data.html#gada171f4740e6a1132b4d4b9c0aea645c":[5,0,0,1,6],
+"group__data.html#gadbd4c895a1e10266d20898996ce53bc0":[3,2,0,45],
+"group__data.html#gadbd4c895a1e10266d20898996ce53bc0":[5,0,0,1,47],
+"group__data.html#gae71bfb440cc4f0b15fe958bf55a3f6af":[3,2,0,16],
+"group__data.html#gae71bfb440cc4f0b15fe958bf55a3f6af":[5,0,0,1,18],
+"group__data.html#gaeab50c7bd297665714861cfcb8f51124":[3,2,0,51],
+"group__data.html#gaeab50c7bd297665714861cfcb8f51124":[5,0,0,1,53],
+"group__data.html#gaeb8b424245ca352fb63dce8ca03cd8da":[3,2,0,66],
+"group__data.html#gaeb8b424245ca352fb63dce8ca03cd8da":[5,0,0,1,68],
+"group__data.html#gaeddd7cf9d968e81ebe72831330e7cd21":[3,2,0,40],
+"group__data.html#gaeddd7cf9d968e81ebe72831330e7cd21":[5,0,0,1,42],
+"group__data.html#gaee6e7a4f78d202cc81657e3976fd68ae":[3,2,0,68],
+"group__data.html#gaee6e7a4f78d202cc81657e3976fd68ae":[5,0,0,1,70],
+"group__data.html#gaef4aa1c6873eb59a46ccaf76c492826f":[3,2,0,59],
+"group__data.html#gaef4aa1c6873eb59a46ccaf76c492826f":[5,0,0,1,61],
+"group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332":[3,2,0,73],
+"group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332":[5,0,0,1,75],
+"group__data.html#gaf76476c18ae09c520a3ae01eaa62cc92":[3,2,0,22],
+"group__data.html#gaf76476c18ae09c520a3ae01eaa62cc92":[5,0,0,1,24],
+"group__data.html#gafccb5008960eb8dc757cb7f9941e5013":[3,2,0,69],
+"group__data.html#gafccb5008960eb8dc757cb7f9941e5013":[5,0,0,1,71],
+"group__data.html#gafe894205eaba01d1caf8ee2aa68ed55c":[3,2,0,55],
+"group__data.html#gafe894205eaba01d1caf8ee2aa68ed55c":[5,0,0,1,57],
+"group__delivery.html":[3,0,5],
+"group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3":[3,0,5,5],
+"group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3":[5,0,0,5,0]
 };


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


[06/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/files.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/files.html b/content/releases/qpid-proton-master/proton/cpp/api/files.html
index 0c6c505..dfa38ca 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/files.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/files.html
@@ -123,14 +123,14 @@ $(document).ready(function(){initNavTree('files.html','');});
 <tr id="row_0_7_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="connection__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="connection__options_8hpp.html" target="_self">connection_options.hpp</a></td><td class="desc">Options for creating a connection. </td></tr>
 <tr id="row_0_8_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="container_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="container_8hpp.html" target="_self">container.hpp</a></td><td class="desc">A top-level container of connections, sessions, and links. </td></tr>
 <tr id="row_0_9_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="decimal_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="decimal_8hpp.html" target="_self">decimal.hpp</a></td><td class="desc">AMQP decimal types </td></tr>
-<tr id="row_0_10_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="default__container_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="default__container_8hpp.html" target="_self">default_container.hpp</a></td><td class="desc"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>. </td></tr>
+<tr id="row_0_10_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="default__container_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="default__container_8hpp.html" target="_self">default_container.hpp</a></td><td class="desc"><b>Deprecated</b> - Use the API in <code><a class="el" href="container_8hpp.html" title="A top-level container of connections, sessions, and links. ">container.hpp</a></code> </td></tr>
 <tr id="row_0_11_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="delivery_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="delivery_8hpp.html" target="_self">delivery.hpp</a></td><td class="desc">A received message. </td></tr>
 <tr id="row_0_12_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="delivery__mode_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="delivery__mode_8hpp.html" target="_self">delivery_mode.hpp</a></td><td class="desc">The message delivery policy to establish when opening a link. </td></tr>
 <tr id="row_0_13_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="duration_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="duration_8hpp.html" target="_self">duration.hpp</a></td><td class="desc">A span of time in milliseconds. </td></tr>
 <tr id="row_0_14_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="endpoint_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="endpoint_8hpp.html" target="_self">endpoint.hpp</a></td><td class="desc">The base class for session, connection, and link. </td></tr>
 <tr id="row_0_15_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="error_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="error_8hpp.html" target="_self">error.hpp</a></td><td class="desc">The base Proton error. </td></tr>
 <tr id="row_0_16_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="error__condition_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="error__condition_8hpp.html" target="_self">error_condition.hpp</a></td><td class="desc">Describes an endpoint error state. </td></tr>
-<tr id="row_0_17_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="function_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="function_8hpp.html" target="_self">function.hpp</a></td><td class="desc"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work.html" title="Unsettled API - A work item for a work queue. ">proton::work</a></code> </td></tr>
+<tr id="row_0_17_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="function_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="function_8hpp.html" target="_self">function.hpp</a></td><td class="desc"><b>Deprecated</b> - Use the API in <code><a class="el" href="work__queue_8hpp.html" title="Unsettled API - A context for thread-safe execution of work. ">work_queue.hpp</a></code> </td></tr>
 <tr id="row_0_18_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="fwd_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="fwd_8hpp.html" target="_self">fwd.hpp</a></td><td class="desc">Forward declarations </td></tr>
 <tr id="row_0_19_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="link_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="link_8hpp.html" target="_self">link.hpp</a></td><td class="desc">A named channel for sending or receiving messages. </td></tr>
 <tr id="row_0_20_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="listen__handler_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="listen__handler_8hpp.html" target="_self">listen_handler.hpp</a></td><td class="desc"><b>Unsettled API</b> - A handler for incoming connections. </td></tr>
@@ -140,36 +140,37 @@ $(document).ready(function(){initNavTree('files.html','');});
 <tr id="row_0_24_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="message__id_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="message__id_8hpp.html" target="_self">message_id.hpp</a></td><td class="desc">An AMQP message ID. </td></tr>
 <tr id="row_0_25_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="messaging__handler_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="messaging__handler_8hpp.html" target="_self">messaging_handler.hpp</a></td><td class="desc">A handler for Proton messaging events. </td></tr>
 <tr id="row_0_26_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="namespaces_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="namespaces_8hpp.html" target="_self">namespaces.hpp</a></td><td class="desc">Namespace declarations </td></tr>
-<tr id="row_0_27_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="receiver_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="receiver_8hpp.html" target="_self">receiver.hpp</a></td><td class="desc">A channel for receiving messages. </td></tr>
-<tr id="row_0_28_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="receiver__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="receiver__options_8hpp.html" target="_self">receiver_options.hpp</a></td><td class="desc">Options for creating a receiver. </td></tr>
-<tr id="row_0_29_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="reconnect__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="reconnect__options_8hpp.html" target="_self">reconnect_options.hpp</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss. </td></tr>
-<tr id="row_0_30_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="returned_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="returned_8hpp.html" target="_self">returned.hpp</a></td><td class="desc">A return type for container methods. </td></tr>
-<tr id="row_0_31_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sasl_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sasl_8hpp.html" target="_self">sasl.hpp</a></td><td class="desc">SASL information. </td></tr>
-<tr id="row_0_32_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="scalar_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="scalar_8hpp.html" target="_self">scalar.hpp</a></td><td class="desc">A holder for an instance of any scalar AMQP type. </td></tr>
-<tr id="row_0_33_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="scalar__base_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="scalar__base_8hpp.html" target="_self">scalar_base.hpp</a></td><td class="desc">The base class for scalar types. </td></tr>
-<tr id="row_0_34_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sender_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sender_8hpp.html" target="_self">sender.hpp</a></td><td class="desc">A channel for sending messages. </td></tr>
-<tr id="row_0_35_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sender__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sender__options_8hpp.html" target="_self">sender_options.hpp</a></td><td class="desc">Options for creating a sender. </td></tr>
-<tr id="row_0_36_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="session_8hpp.html" target="_self">session.hpp</a></td><td class="desc">A container of senders and receivers. </td></tr>
-<tr id="row_0_37_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="session__options_8hpp.html" target="_self">session_options.hpp</a></td><td class="desc">Options for creating a session. </td></tr>
-<tr id="row_0_38_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="source_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="source_8hpp.html" target="_self">source.hpp</a></td><td class="desc">A point of origin for messages. </td></tr>
-<tr id="row_0_39_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="source__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="source__options_8hpp.html" target="_self">source_options.hpp</a></td><td class="desc">Options for creating a source node for a sender or receiver. </td></tr>
-<tr id="row_0_40_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="ssl_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="ssl_8hpp.html" target="_self">ssl.hpp</a></td><td class="desc">SSL information. </td></tr>
-<tr id="row_0_41_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="symbol_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="symbol_8hpp.html" target="_self">symbol.hpp</a></td><td class="desc">A string that represents the AMQP symbol type. </td></tr>
-<tr id="row_0_42_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="target_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="target_8hpp.html" target="_self">target.hpp</a></td><td class="desc">A destination for messages. </td></tr>
-<tr id="row_0_43_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="target__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="target__options_8hpp.html" target="_self">target_options.hpp</a></td><td class="desc">Options for creating a target node for a sender or receiver. </td></tr>
-<tr id="row_0_44_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="terminus_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="terminus_8hpp.html" target="_self">terminus.hpp</a></td><td class="desc">One end of a link, either a source or a target. </td></tr>
-<tr id="row_0_45_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="thread__safe_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="thread__safe_8hpp.html" target="_self">thread_safe.hpp</a></td><td class="desc"><b>Deprecated</b> - Container method return values are safe to use only inside handlers </td></tr>
-<tr id="row_0_46_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="timestamp_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="timestamp_8hpp.html" target="_self">timestamp.hpp</a></td><td class="desc">A 64-bit timestamp in milliseconds since the Unix epoch. </td></tr>
-<tr id="row_0_47_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="tracker_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="tracker_8hpp.html" target="_self">tracker.hpp</a></td><td class="desc">A tracker for a sent message. </td></tr>
-<tr id="row_0_48_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transfer_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="transfer_8hpp.html" target="_self">transfer.hpp</a></td><td class="desc">The base class for delivery and tracker. </td></tr>
-<tr id="row_0_49_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transport_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="transport_8hpp.html" target="_self">transport.hpp</a></td><td class="desc">A network channel supporting an AMQP connection. </td></tr>
-<tr id="row_0_50_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="type__id_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="type__id_8hpp.html" target="_self">type_id.hpp</a></td><td class="desc">Type IDs for AMQP data types </td></tr>
-<tr id="row_0_51_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="types_8hpp.html" target="_self">types.hpp</a></td><td class="desc">Proton types used to represent AMQP types </td></tr>
-<tr id="row_0_52_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types__fwd_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="types__fwd_8hpp.html" target="_self">types_fwd.hpp</a></td><td class="desc">Forward declarations for Proton types used to represent AMQP types </td></tr>
-<tr id="row_0_53_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="url_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="url_8hpp.html" target="_self">url.hpp</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library. </td></tr>
-<tr id="row_0_54_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="uuid_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="uuid_8hpp.html" target="_self">uuid.hpp</a></td><td class="desc">A 16-byte universally unique identifier. </td></tr>
-<tr id="row_0_55_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="value_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="value_8hpp.html" target="_self">value.hpp</a></td><td class="desc">A holder for any AMQP value, simple or complex. </td></tr>
-<tr id="row_0_56_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="work__queue_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="work__queue_8hpp.html" target="_self">work_queue.hpp</a></td><td class="desc"><b>Unsettled API</b> - A context for thread-safe execution of work. </td></tr>
+<tr id="row_0_27_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="null_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="null_8hpp.html" target="_self">null.hpp</a></td><td class="desc">The type of the AMQP null value. </td></tr>
+<tr id="row_0_28_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="receiver_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="receiver_8hpp.html" target="_self">receiver.hpp</a></td><td class="desc">A channel for receiving messages. </td></tr>
+<tr id="row_0_29_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="receiver__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="receiver__options_8hpp.html" target="_self">receiver_options.hpp</a></td><td class="desc">Options for creating a receiver. </td></tr>
+<tr id="row_0_30_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="reconnect__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="reconnect__options_8hpp.html" target="_self">reconnect_options.hpp</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss. </td></tr>
+<tr id="row_0_31_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="returned_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="returned_8hpp.html" target="_self">returned.hpp</a></td><td class="desc">A return type for container methods. </td></tr>
+<tr id="row_0_32_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sasl_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sasl_8hpp.html" target="_self">sasl.hpp</a></td><td class="desc">SASL information. </td></tr>
+<tr id="row_0_33_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="scalar_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="scalar_8hpp.html" target="_self">scalar.hpp</a></td><td class="desc">A holder for an instance of any scalar AMQP type. </td></tr>
+<tr id="row_0_34_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="scalar__base_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="scalar__base_8hpp.html" target="_self">scalar_base.hpp</a></td><td class="desc">The base class for scalar types. </td></tr>
+<tr id="row_0_35_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sender_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sender_8hpp.html" target="_self">sender.hpp</a></td><td class="desc">A channel for sending messages. </td></tr>
+<tr id="row_0_36_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="sender__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="sender__options_8hpp.html" target="_self">sender_options.hpp</a></td><td class="desc">Options for creating a sender. </td></tr>
+<tr id="row_0_37_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="session_8hpp.html" target="_self">session.hpp</a></td><td class="desc">A container of senders and receivers. </td></tr>
+<tr id="row_0_38_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="session__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="session__options_8hpp.html" target="_self">session_options.hpp</a></td><td class="desc">Options for creating a session. </td></tr>
+<tr id="row_0_39_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="source_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="source_8hpp.html" target="_self">source.hpp</a></td><td class="desc">A point of origin for messages. </td></tr>
+<tr id="row_0_40_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="source__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="source__options_8hpp.html" target="_self">source_options.hpp</a></td><td class="desc">Options for creating a source node for a sender or receiver. </td></tr>
+<tr id="row_0_41_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="ssl_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="ssl_8hpp.html" target="_self">ssl.hpp</a></td><td class="desc">SSL information. </td></tr>
+<tr id="row_0_42_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="symbol_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="symbol_8hpp.html" target="_self">symbol.hpp</a></td><td class="desc">A string that represents the AMQP symbol type. </td></tr>
+<tr id="row_0_43_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="target_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="target_8hpp.html" target="_self">target.hpp</a></td><td class="desc">A destination for messages. </td></tr>
+<tr id="row_0_44_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="target__options_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="target__options_8hpp.html" target="_self">target_options.hpp</a></td><td class="desc">Options for creating a target node for a sender or receiver. </td></tr>
+<tr id="row_0_45_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="terminus_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="terminus_8hpp.html" target="_self">terminus.hpp</a></td><td class="desc">One end of a link, either a source or a target. </td></tr>
+<tr id="row_0_46_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="thread__safe_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="thread__safe_8hpp.html" target="_self">thread_safe.hpp</a></td><td class="desc"><b>Deprecated</b> - No longer used </td></tr>
+<tr id="row_0_47_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="timestamp_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="timestamp_8hpp.html" target="_self">timestamp.hpp</a></td><td class="desc">A 64-bit timestamp in milliseconds since the Unix epoch. </td></tr>
+<tr id="row_0_48_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="tracker_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="tracker_8hpp.html" target="_self">tracker.hpp</a></td><td class="desc">A tracker for a sent message. </td></tr>
+<tr id="row_0_49_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transfer_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="transfer_8hpp.html" target="_self">transfer.hpp</a></td><td class="desc">The base class for delivery and tracker. </td></tr>
+<tr id="row_0_50_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="transport_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="transport_8hpp.html" target="_self">transport.hpp</a></td><td class="desc">A network channel supporting an AMQP connection. </td></tr>
+<tr id="row_0_51_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="type__id_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="type__id_8hpp.html" target="_self">type_id.hpp</a></td><td class="desc">Type IDs for AMQP data types </td></tr>
+<tr id="row_0_52_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="types_8hpp.html" target="_self">types.hpp</a></td><td class="desc">Proton types used to represent AMQP types </td></tr>
+<tr id="row_0_53_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="types__fwd_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="types__fwd_8hpp.html" target="_self">types_fwd.hpp</a></td><td class="desc">Forward declarations for Proton types used to represent AMQP types </td></tr>
+<tr id="row_0_54_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="url_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="url_8hpp.html" target="_self">url.hpp</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
+<tr id="row_0_55_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="uuid_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="uuid_8hpp.html" target="_self">uuid.hpp</a></td><td class="desc">A 16-byte universally unique identifier. </td></tr>
+<tr id="row_0_56_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="value_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="value_8hpp.html" target="_self">value.hpp</a></td><td class="desc">A holder for any AMQP value, simple or complex. </td></tr>
+<tr id="row_0_57_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><a href="work__queue_8hpp_source.html"><span class="icondoc"></span></a><a class="el" href="work__queue_8hpp.html" target="_self">work_queue.hpp</a></td><td class="desc"><b>Unsettled API</b> - A context for thread-safe execution of work. </td></tr>
 </table>
 </div><!-- directory -->
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/function_8hpp.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/function_8hpp.html b/content/releases/qpid-proton-master/proton/cpp/api/function_8hpp.html
index 1044c41..76da218 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/function_8hpp.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/function_8hpp.html
@@ -94,12 +94,12 @@ $(document).ready(function(){initNavTree('function_8hpp.html','');});
 </div><!--header-->
 <div class="contents">
 
-<p><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work.html" title="Unsettled API - A work item for a work queue. ">proton::work</a></code>.  
+<p><b>Deprecated</b> - Use the API in <code><a class="el" href="work__queue_8hpp.html" title="Unsettled API - A context for thread-safe execution of work. ">work_queue.hpp</a></code>.  
 <a href="#details">More...</a></p>
 
 <p><a href="function_8hpp_source.html">Go to the source code of this file.</a></p>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
-<div class="textblock"><p><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work.html" title="Unsettled API - A work item for a work queue. ">proton::work</a></code>. </p>
+<div class="textblock"><p><b>Deprecated</b> - Use the API in <code><a class="el" href="work__queue_8hpp.html" title="Unsettled API - A context for thread-safe execution of work. ">work_queue.hpp</a></code>. </p>
 </div></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_c.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_c.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_c.html
index 75784c3..3ce3d38 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_c.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_c.html
@@ -92,6 +92,11 @@ $(document).ready(function(){initNavTree('functions_c.html','');});
 <div class="textblock">Here is a list of all documented class members with links to the class documentation for each member:</div>
 
 <h3><a id="index_c"></a>- c -</h3><ul>
+<li>capabilities()
+: <a class="el" href="classproton_1_1source__options.html#aeaddb5ce3dec75cc6e55f3249adfe454">source_options</a>
+, <a class="el" href="classproton_1_1target__options.html#aec90fa88e34bccd5a121baa6c7e9e95a">target_options</a>
+, <a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">terminus</a>
+</li>
 <li>clear()
 : <a class="el" href="classproton_1_1map.html#ac8bb3912a3ce86b15842e79d0b421204">map&lt; K, T &gt;</a>
 , <a class="el" href="classproton_1_1message.html#ac8bb3912a3ce86b15842e79d0b421204">message</a>
@@ -102,7 +107,7 @@ $(document).ready(function(){initNavTree('functions_c.html','');});
 : <a class="el" href="classproton_1_1container.html#a913a88786abbbf08dd3e53e2a3e4accb">container</a>
 </li>
 <li>close()
-: <a class="el" href="classproton_1_1connection.html#a817883d28ce0ac8a29d917d196796f68">connection</a>
+: <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">connection</a>
 , <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>
 , <a class="el" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">link</a>
 , <a class="el" href="classproton_1_1session.html#a5ae591df94fc66ccb85cbb6565368bca">session</a>
@@ -144,16 +149,17 @@ $(document).ready(function(){initNavTree('functions_c.html','');});
 : <a class="el" href="classproton_1_1io_1_1connection__driver.html#a57f27e412ea5d79e071da546dc40aed9">connection_driver</a>
 </li>
 <li>connection_options()
-: <a class="el" href="classproton_1_1connection__options.html#a90933e18af82770dfa522b0e3b356f3e">connection_options</a>
+: <a class="el" href="classproton_1_1connection__options.html#a8034b8d17ca30a4cfc3db8c6a898dc4d">connection_options</a>
 </li>
 <li>const_buffer()
 : <a class="el" href="structproton_1_1io_1_1const__buffer.html#a91a09264a182ec89354136e9b2c51fe4">const_buffer</a>
 </li>
 <li>container()
 : <a class="el" href="classproton_1_1connection.html#a2f632b80247e868b8264b8a025b84baf">connection</a>
-, <a class="el" href="classproton_1_1container.html#a822ca363beceb76ffdc5ce370a4f9356">container</a>
+, <a class="el" href="classproton_1_1container.html#a9a322df81c8d397bb4c3fa6c1a67a496">container</a>
 , <a class="el" href="classproton_1_1io_1_1connection__driver.html#a2129b84576000b05021be09896a3e59c">connection_driver</a>
 , <a class="el" href="classproton_1_1link.html#a2f632b80247e868b8264b8a025b84baf">link</a>
+, <a class="el" href="classproton_1_1listener.html#a2f632b80247e868b8264b8a025b84baf">listener</a>
 , <a class="el" href="classproton_1_1session.html#a2f632b80247e868b8264b8a025b84baf">session</a>
 , <a class="el" href="classproton_1_1transfer.html#a2f632b80247e868b8264b8a025b84baf">transfer</a>
 </li>
@@ -180,7 +186,7 @@ $(document).ready(function(){initNavTree('functions_c.html','');});
 : <a class="el" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">message</a>
 </li>
 <li>creation_time()
-: <a class="el" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">message</a>
+: <a class="el" href="classproton_1_1message.html#a52000cda4f3d84e541a6aa15dfe3bbbc">message</a>
 </li>
 <li>credit()
 : <a class="el" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">link</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_d.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_d.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_d.html
index 65df8ce..fcf1962 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_d.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_d.html
@@ -115,6 +115,9 @@ $(document).ready(function(){initNavTree('functions_d.html','');});
 <li>delay_multiplier()
 : <a class="el" href="classproton_1_1reconnect__options.html#a8456389a8174cf6d2ae2550e05e3e650">reconnect_options</a>
 </li>
+<li>delivery_annotations()
+: <a class="el" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">message</a>
+</li>
 <li>delivery_count()
 : <a class="el" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">message</a>
 </li>
@@ -147,7 +150,7 @@ $(document).ready(function(){initNavTree('functions_d.html','');});
 <li>durability_mode()
 : <a class="el" href="classproton_1_1source__options.html#a89176218ec0f2754c6499935368627ab">source_options</a>
 , <a class="el" href="classproton_1_1target__options.html#a8ebe0e28560c7873712674314ac9547d">target_options</a>
-, <a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">terminus</a>
+, <a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3d">terminus</a>
 </li>
 <li>durable()
 : <a class="el" href="classproton_1_1message.html#a84f7e28685ffb38fb86e9896743600cd">message</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func.html
index b96a870..0aba25a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func.html
@@ -103,7 +103,7 @@ $(document).ready(function(){initNavTree('functions_func.html','');});
 , <a class="el" href="classproton_1_1session.html#ad9735e23cb0888fb98e1c5893aecff7e">session</a>
 </li>
 <li>add()
-: <a class="el" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">work_queue</a>
+: <a class="el" href="classproton_1_1work__queue.html#a7525d36e11cc3eb9d483e8e81713ab6d">work_queue</a>
 </li>
 <li>add_credit()
 : <a class="el" href="classproton_1_1receiver.html#a84d3a001340d11201e03c6ed7c763641">receiver</a>
@@ -115,7 +115,7 @@ $(document).ready(function(){initNavTree('functions_func.html','');});
 , <a class="el" href="classproton_1_1target__options.html#a39a0acbf2c7de97e77df483ca9c4c6a9">target_options</a>
 </li>
 <li>annotation_key()
-: <a class="el" href="classproton_1_1annotation__key.html#afdd676d37486aa26af7fdd588f994d26">annotation_key</a>
+: <a class="el" href="classproton_1_1annotation__key.html#a056f77e21066cbf900772853454102a8">annotation_key</a>
 </li>
 <li>auto_accept()
 : <a class="el" href="classproton_1_1receiver__options.html#a9b9ad83418de47f87c6c7062eaefb5b6">receiver_options</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_c.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_c.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_c.html
index 689f9eb..27278ba 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_c.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_c.html
@@ -92,6 +92,11 @@ $(document).ready(function(){initNavTree('functions_func_c.html','');});
 &#160;
 
 <h3><a id="index_c"></a>- c -</h3><ul>
+<li>capabilities()
+: <a class="el" href="classproton_1_1source__options.html#aeaddb5ce3dec75cc6e55f3249adfe454">source_options</a>
+, <a class="el" href="classproton_1_1target__options.html#aec90fa88e34bccd5a121baa6c7e9e95a">target_options</a>
+, <a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">terminus</a>
+</li>
 <li>clear()
 : <a class="el" href="classproton_1_1map.html#ac8bb3912a3ce86b15842e79d0b421204">map&lt; K, T &gt;</a>
 , <a class="el" href="classproton_1_1message.html#ac8bb3912a3ce86b15842e79d0b421204">message</a>
@@ -102,7 +107,7 @@ $(document).ready(function(){initNavTree('functions_func_c.html','');});
 : <a class="el" href="classproton_1_1container.html#a913a88786abbbf08dd3e53e2a3e4accb">container</a>
 </li>
 <li>close()
-: <a class="el" href="classproton_1_1connection.html#a817883d28ce0ac8a29d917d196796f68">connection</a>
+: <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">connection</a>
 , <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>
 , <a class="el" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">link</a>
 , <a class="el" href="classproton_1_1session.html#a5ae591df94fc66ccb85cbb6565368bca">session</a>
@@ -145,9 +150,10 @@ $(document).ready(function(){initNavTree('functions_func_c.html','');});
 </li>
 <li>container()
 : <a class="el" href="classproton_1_1connection.html#a2f632b80247e868b8264b8a025b84baf">connection</a>
-, <a class="el" href="classproton_1_1container.html#a822ca363beceb76ffdc5ce370a4f9356">container</a>
+, <a class="el" href="classproton_1_1container.html#a88125a4442a7b28fab97a89587627c0f">container</a>
 , <a class="el" href="classproton_1_1io_1_1connection__driver.html#a2129b84576000b05021be09896a3e59c">connection_driver</a>
 , <a class="el" href="classproton_1_1link.html#a2f632b80247e868b8264b8a025b84baf">link</a>
+, <a class="el" href="classproton_1_1listener.html#a2f632b80247e868b8264b8a025b84baf">listener</a>
 , <a class="el" href="classproton_1_1session.html#a2f632b80247e868b8264b8a025b84baf">session</a>
 , <a class="el" href="classproton_1_1transfer.html#a2f632b80247e868b8264b8a025b84baf">transfer</a>
 </li>
@@ -156,7 +162,7 @@ $(document).ready(function(){initNavTree('functions_func_c.html','');});
 , <a class="el" href="classproton_1_1connection__options.html#a4c6429303ccb719d9c585c88f300e007">connection_options</a>
 </li>
 <li>content_encoding()
-: <a class="el" href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">message</a>
+: <a class="el" href="classproton_1_1message.html#a4989509fabaa148e9e56030cf0b9d23d">message</a>
 </li>
 <li>content_type()
 : <a class="el" href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">message</a>
@@ -165,13 +171,13 @@ $(document).ready(function(){initNavTree('functions_func_c.html','');});
 : <a class="el" href="structproton_1_1conversion__error.html#a34e1a24b99f9580dc7af4e9252d95ea2">conversion_error</a>
 </li>
 <li>copy()
-: <a class="el" href="classproton_1_1uuid.html#a01615bb9bde7ec7791a644adfc05aa7e">uuid</a>
+: <a class="el" href="classproton_1_1uuid.html#aeafd1bdbc8df5395f14651a651fbf1f9">uuid</a>
 </li>
 <li>correlation_id()
-: <a class="el" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">message</a>
+: <a class="el" href="classproton_1_1message.html#ad159656f1742235cd22a9c6aaabf9d2d">message</a>
 </li>
 <li>creation_time()
-: <a class="el" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">message</a>
+: <a class="el" href="classproton_1_1message.html#a52000cda4f3d84e541a6aa15dfe3bbbc">message</a>
 </li>
 <li>credit()
 : <a class="el" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">link</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_d.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_d.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_d.html
index dc0317c..8865d6f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_d.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_d.html
@@ -108,6 +108,9 @@ $(document).ready(function(){initNavTree('functions_func_d.html','');});
 <li>delay_multiplier()
 : <a class="el" href="classproton_1_1reconnect__options.html#a8456389a8174cf6d2ae2550e05e3e650">reconnect_options</a>
 </li>
+<li>delivery_annotations()
+: <a class="el" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">message</a>
+</li>
 <li>delivery_count()
 : <a class="el" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">message</a>
 </li>
@@ -143,7 +146,7 @@ $(document).ready(function(){initNavTree('functions_func_d.html','');});
 , <a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">terminus</a>
 </li>
 <li>durable()
-: <a class="el" href="classproton_1_1message.html#a84f7e28685ffb38fb86e9896743600cd">message</a>
+: <a class="el" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">message</a>
 </li>
 <li>duration()
 : <a class="el" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_l.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_l.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_l.html
index 2d68b5d..faa6d1a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_l.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_l.html
@@ -99,7 +99,7 @@ $(document).ready(function(){initNavTree('functions_func_l.html','');});
 : <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">container</a>
 </li>
 <li>listener()
-: <a class="el" href="classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814">listener</a>
+: <a class="el" href="classproton_1_1listener.html#a3edec85cbcde06b471e8e2fb4726dbf5">listener</a>
 </li>
 </ul>
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_m.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_m.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_m.html
index d241017..2ece386 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_m.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_m.html
@@ -115,8 +115,11 @@ $(document).ready(function(){initNavTree('functions_func_m.html','');});
 <li>message()
 : <a class="el" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>
 </li>
+<li>message_annotations()
+: <a class="el" href="classproton_1_1message.html#a05ea365ef83130c85ffbb74498955ca3">message</a>
+</li>
 <li>message_id()
-: <a class="el" href="classproton_1_1message__id.html#afb6e34ccd03d666d3e5cd4312064c4a3">message_id</a>
+: <a class="el" href="classproton_1_1message__id.html#a37823024300ef4413ca077df9ddcc4d2">message_id</a>
 </li>
 <li>milliseconds()
 : <a class="el" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">duration</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_n.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_n.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_n.html
index 5d4ebc7..de47ecb 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_n.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_n.html
@@ -95,6 +95,8 @@ $(document).ready(function(){initNavTree('functions_func_n.html','');});
 <li>name()
 : <a class="el" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb69367171">error_condition</a>
 , <a class="el" href="classproton_1_1link.html#a1d89c28bd42ba9a52da008bb69367171">link</a>
+, <a class="el" href="classproton_1_1receiver__options.html#a038ed50e63983958b13e42d49d270b88">receiver_options</a>
+, <a class="el" href="classproton_1_1sender__options.html#af37454934677c6f0e8bbe8bb1087f1ed">sender_options</a>
 </li>
 <li>next_type()
 : <a class="el" href="classproton_1_1codec_1_1decoder.html#af3a00236ce433d05e26c0eb2ed5dfcd0">decoder</a>
@@ -105,6 +107,9 @@ $(document).ready(function(){initNavTree('functions_func_n.html','');});
 <li>now()
 : <a class="el" href="classproton_1_1timestamp.html#a8a432817c74685a518a08ede48d1db34">timestamp</a>
 </li>
+<li>null()
+: <a class="el" href="classproton_1_1null.html#ac6f7583eff281f509c7351b850ad131b">null</a>
+</li>
 </ul>
 </div><!-- contents -->
 </div><!-- doc-content -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_o.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_o.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_o.html
index 3ec413b..6e1b7ef 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_o.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_o.html
@@ -93,101 +93,104 @@ $(document).ready(function(){initNavTree('functions_func_o.html','');});
 
 <h3><a id="index_o"></a>- o -</h3><ul>
 <li>on_accept()
-: <a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">listen_handler</a>
+: <a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">listen_handler</a>
 </li>
 <li>on_close()
 : <a class="el" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">listen_handler</a>
 </li>
 <li>on_connection_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a804f0ea9c2754f143624b4078a61f650">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a8368c2f41b5c1dab4aa063c1c78a6e19">messaging_handler</a>
 </li>
 <li>on_connection_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#aafa83dc2f8f477ba1f76e86dc69cd1e9">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae93110a9bad4868663f37d15cd3139a4">messaging_handler</a>
 </li>
 <li>on_connection_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">messaging_handler</a>
 </li>
 <li>on_connection_wake()
 : <a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481">messaging_handler</a>
 </li>
 <li>on_container_start()
-: <a class="el" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">messaging_handler</a>
 </li>
 <li>on_container_stop()
-: <a class="el" href="classproton_1_1messaging__handler.html#ab5bb8195e26c8818c4f57a734566ecfd">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">messaging_handler</a>
 </li>
 <li>on_delivery_settle()
-: <a class="el" href="classproton_1_1messaging__handler.html#afc96eabc76c471d61627493eadb58ac8">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a4f0e5cebf65a87f301ba5ef82eb8537d">messaging_handler</a>
 </li>
 <li>on_error()
 : <a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">listen_handler</a>
-, <a class="el" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">messaging_handler</a>
+, <a class="el" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">messaging_handler</a>
 </li>
 <li>on_message()
-: <a class="el" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">messaging_handler</a>
+</li>
+<li>on_open()
+: <a class="el" href="classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b">listen_handler</a>
 </li>
 <li>on_receiver_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28">messaging_handler</a>
 </li>
 <li>on_receiver_detach()
-: <a class="el" href="classproton_1_1messaging__handler.html#a93ab65773954cf12eb7f76a26aa44cfe">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a06b10fbf8524545eaf88def91d7235ef">messaging_handler</a>
 </li>
 <li>on_receiver_drain_finish()
-: <a class="el" href="classproton_1_1messaging__handler.html#a815e30c6d10d923d88dc1085b7b0f116">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a0c3ba013a3515fd3d0a1871c984e497e">messaging_handler</a>
 </li>
 <li>on_receiver_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0c281aee5483822bdf4b428834bd7f28">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac0daca9ec2dc45353a04069c6a12f3aa">messaging_handler</a>
 </li>
 <li>on_receiver_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401">messaging_handler</a>
 </li>
 <li>on_sendable()
-: <a class="el" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">messaging_handler</a>
 </li>
 <li>on_sender_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29">messaging_handler</a>
 </li>
 <li>on_sender_detach()
-: <a class="el" href="classproton_1_1messaging__handler.html#a731e7cdbda64b15f069efd560b66ada1">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae103f0e8f35a8aebfb14b96c298ed938">messaging_handler</a>
 </li>
 <li>on_sender_drain_start()
-: <a class="el" href="classproton_1_1messaging__handler.html#ad3d23a7c3849dabd137610f8ee1569e3">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac07a9aab7eee64a7415f1cacc278344b">messaging_handler</a>
 </li>
 <li>on_sender_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#a2d9d98eee878f1e734457ba01e21228a">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a2347cff02f9ed958ca41fcc31e58d792">messaging_handler</a>
 </li>
 <li>on_sender_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">messaging_handler</a>
 </li>
 <li>on_session_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a54fe4fc5394418f8606f9263f13d2e98">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa3ff10317b9fdcbe00e500cb1e9c96ec">messaging_handler</a>
 </li>
 <li>on_session_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#aca924d2f68649df7945719be3d29a597">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a63bb630e8dc357b22d6c33781c7c6a11">messaging_handler</a>
 </li>
 <li>on_session_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#adddbfd9b7fc7719490bdc21331c42302">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aad43a0028727310bcdbd8f63feb99537">messaging_handler</a>
 </li>
 <li>on_tracker_accept()
-: <a class="el" href="classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a4e61812588fe6fbde253b41f7c02e993">messaging_handler</a>
 </li>
 <li>on_tracker_reject()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0740e8c9ed9d0c304d2adced09802893">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a116c831b8a80727a451ce20c44d781f8">messaging_handler</a>
 </li>
 <li>on_tracker_release()
-: <a class="el" href="classproton_1_1messaging__handler.html#acfde5590c6e826ef9e2c33a28edefe19">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ad107964511dce62449ca730e9b0aca88">messaging_handler</a>
 </li>
 <li>on_tracker_settle()
-: <a class="el" href="classproton_1_1messaging__handler.html#a023a5c57eeeaf79ed5b768cd172ad0ac">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a36620e631024c73f5c6766abf95a8356">messaging_handler</a>
 </li>
 <li>on_transport_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f">messaging_handler</a>
 </li>
 <li>on_transport_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665">messaging_handler</a>
 </li>
 <li>on_transport_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0c141065eda9a26916ccc63ccea5d3b7">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa68ce0021c22cc956890c6bcc5384b84">messaging_handler</a>
 </li>
 <li>open()
 : <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab">connection</a>
@@ -202,11 +205,11 @@ $(document).ready(function(){initNavTree('functions_func_o.html','');});
 </li>
 <li>open_sender()
 : <a class="el" href="classproton_1_1connection.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">connection</a>
-, <a class="el" href="classproton_1_1container.html#ab868043d49b61929cf852b725816faf9">container</a>
+, <a class="el" href="classproton_1_1container.html#ace90c31b569a4e5e8b435be43ded9ccb">container</a>
 , <a class="el" href="classproton_1_1session.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">session</a>
 </li>
 <li>open_session()
-: <a class="el" href="classproton_1_1connection.html#ae922e54bbff7c2d27373eea9d15e3367">connection</a>
+: <a class="el" href="classproton_1_1connection.html#a417060fdeea996b1684bd0fecc6c6420">connection</a>
 </li>
 <li>operator bool()
 : <a class="el" href="classproton_1_1error__condition.html#a67b76affb3b5d35fa419ac234144038b">error_condition</a>
@@ -221,9 +224,6 @@ $(document).ready(function(){initNavTree('functions_func_o.html','');});
 <li>operator!()
 : <a class="el" href="classproton_1_1error__condition.html#a61efd4196a96540ee018fee8791f3f10">error_condition</a>
 </li>
-<li>operator()()
-: <a class="el" href="classproton_1_1work.html#a5ccbdeb5350ba8528eab7e4cc49fc68b">work</a>
-</li>
 <li>operator&lt;&lt;()
 : <a class="el" href="classproton_1_1codec_1_1encoder.html#a041e90045de495b728fb95bbed97a531">encoder</a>
 </li>
@@ -231,8 +231,9 @@ $(document).ready(function(){initNavTree('functions_func_o.html','');});
 : <a class="el" href="classproton_1_1binary.html#ac04f4568094b18213b75d4400d8e2477">binary</a>
 , <a class="el" href="classproton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">connection_options</a>
 , <a class="el" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">duration</a>
-, <a class="el" href="classproton_1_1map.html#a16a75d371d4e6287b352f5066643f030">map&lt; K, T &gt;</a>
-, <a class="el" href="classproton_1_1message.html#ac7abf26f9566b75b59af27ca13b2182f">message</a>
+, <a class="el" href="classproton_1_1listener.html#a426fa804e3bb58ef90b29b066c3f5199">listener</a>
+, <a class="el" href="classproton_1_1map.html#ada6de583b7cdc95792661bcc0ff8a517">map&lt; K, T &gt;</a>
+, <a class="el" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">message</a>
 , <a class="el" href="classproton_1_1message__id.html#a0e4798868734cc90ea4e9ed3ca870d3d">message_id</a>
 , <a class="el" href="classproton_1_1receiver__options.html#a815be8018205013b8ff011d4b62b7324">receiver_options</a>
 , <a class="el" href="classproton_1_1reconnect__options.html#aea298c3d006e10b7da6608591949b270">reconnect_options</a>
@@ -246,7 +247,7 @@ $(document).ready(function(){initNavTree('functions_func_o.html','');});
 , <a class="el" href="classproton_1_1value.html#ad139f5042c366b09078f123f5621c156">value</a>
 </li>
 <li>operator&gt;&gt;()
-: <a class="el" href="classproton_1_1codec_1_1decoder.html#a29037b1d70f61e041b2d5be7c67b577d">decoder</a>
+: <a class="el" href="classproton_1_1codec_1_1decoder.html#ac6c6ddca9af56625b28bc7989b02f24b">decoder</a>
 </li>
 <li>outcome()
 : <a class="el" href="classproton_1_1sasl.html#aee5a4997bbfa58f1b8176f936618de00">sasl</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_p.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_p.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_p.html
index 3120386..34c879e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_p.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_p.html
@@ -100,7 +100,8 @@ $(document).ready(function(){initNavTree('functions_func_p.html','');});
 : <a class="el" href="classproton_1_1url.html#ac4cb5f95f1d720ef0cc94b74152cf50b">url</a>
 </li>
 <li>port()
-: <a class="el" href="classproton_1_1url.html#a6f16e8b68942ad0d21494d056b4e13d7">url</a>
+: <a class="el" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">listener</a>
+, <a class="el" href="classproton_1_1url.html#a6f16e8b68942ad0d21494d056b4e13d7">url</a>
 </li>
 <li>port_int()
 : <a class="el" href="classproton_1_1url.html#aa54f07362c271f7f550c3f904022329b">url</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_r.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_r.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_r.html
index 9b467a8..04b676c 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_r.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_r.html
@@ -118,7 +118,7 @@ $(document).ready(function(){initNavTree('functions_func_r.html','');});
 , <a class="el" href="classproton_1_1session.html#a634a0b14e10b9fc50cbb52251c2c8027">session</a>
 </li>
 <li>reconnect()
-: <a class="el" href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">connection_options</a>
+: <a class="el" href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">connection_options</a>
 </li>
 <li>reconnect_options()
 : <a class="el" href="classproton_1_1reconnect__options.html#aef23a4a6b4f399f86ba458e855e0ca08">reconnect_options</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_s.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_s.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_s.html
index eb26559..46af1f2 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_s.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_s.html
@@ -168,22 +168,21 @@ $(document).ready(function(){initNavTree('functions_func_s.html','');});
 , <a class="el" href="classproton_1_1source.html#a6cfde826a3d3092bd8a3a636e2336bbb">source</a>
 </li>
 <li>source_options()
-: <a class="el" href="classproton_1_1source__options.html#a1d2323580261c3bce5c41cb93d72bff9">source_options</a>
+: <a class="el" href="classproton_1_1source__options.html#afb2122d3d1a1f504c7cb23ea1093afcf">source_options</a>
 </li>
 <li>ssl()
-: <a class="el" href="classproton_1_1ssl.html#aab73a626b87b792e31ff0eee531fbcb2">ssl</a>
-, <a class="el" href="classproton_1_1transport.html#a73fe833a759ac581baa889155b7d0633">transport</a>
+: <a class="el" href="classproton_1_1transport.html#a73fe833a759ac581baa889155b7d0633">transport</a>
 </li>
 <li>ssl_certificate()
-: <a class="el" href="classproton_1_1ssl__certificate.html#aa23f3c38df56f3e9ea116462c6c98547">ssl_certificate</a>
+: <a class="el" href="classproton_1_1ssl__certificate.html#a8db4264dc2c610f8cc91903610f48361">ssl_certificate</a>
 </li>
 <li>ssl_client_options()
 : <a class="el" href="classproton_1_1connection__options.html#a4eb280b5a62adb5b2075d6316a590c70">connection_options</a>
-, <a class="el" href="classproton_1_1ssl__client__options.html#a05df3dc53e9dc80ed8d90b7724d791b0">ssl_client_options</a>
+, <a class="el" href="classproton_1_1ssl__client__options.html#a79e03058960606b2d656b57744d13284">ssl_client_options</a>
 </li>
 <li>ssl_server_options()
 : <a class="el" href="classproton_1_1connection__options.html#a5ce3c4591be545f5ae67f22ef64fb9ef">connection_options</a>
-, <a class="el" href="classproton_1_1ssl__server__options.html#a557e872dfb469537d374f04b969db547">ssl_server_options</a>
+, <a class="el" href="classproton_1_1ssl__server__options.html#abf0b30171760149fc5e8dacacbcd0b00">ssl_server_options</a>
 </li>
 <li>state()
 : <a class="el" href="classproton_1_1transfer.html#a8073c1382e7adf81536001a8007924a5">transfer</a>
@@ -199,7 +198,7 @@ $(document).ready(function(){initNavTree('functions_func_s.html','');});
 : <a class="el" href="classproton_1_1message.html#a35502b25971d91fb8fc1dea7f364f541">message</a>
 </li>
 <li>symbol()
-: <a class="el" href="classproton_1_1symbol.html#a3ab37ae3b314e64dd5b19f8f01148bbf">symbol</a>
+: <a class="el" href="classproton_1_1symbol.html#a5d96e10a5b46e6d9a4cc999cbd7c1467">symbol</a>
 </li>
 </ul>
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_func_w.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_w.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_w.html
index afad35f..707b846 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_func_w.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_func_w.html
@@ -98,15 +98,12 @@ $(document).ready(function(){initNavTree('functions_func_w.html','');});
 <li>what()
 : <a class="el" href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">error_condition</a>
 </li>
-<li>work()
-: <a class="el" href="classproton_1_1work.html#a9d5564deaef15633884ee408f0e92f3a">work</a>
-</li>
 <li>work_queue()
 : <a class="el" href="classproton_1_1connection.html#a7c755d6ac6385e007adb61966598ba63">connection</a>
 , <a class="el" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">link</a>
 , <a class="el" href="classproton_1_1session.html#a7c755d6ac6385e007adb61966598ba63">session</a>
 , <a class="el" href="classproton_1_1transfer.html#a7c755d6ac6385e007adb61966598ba63">transfer</a>
-, <a class="el" href="classproton_1_1work__queue.html#a1e7fdf3236c9477c0462214080c34689">work_queue</a>
+, <a class="el" href="classproton_1_1work__queue.html#a689e0d941a552db276229a9fc312e143">work_queue</a>
 </li>
 <li>write_buffer()
 : <a class="el" href="classproton_1_1io_1_1connection__driver.html#aca2fdb0871921fc22ba7c119f8c624f5">connection_driver</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_l.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_l.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_l.html
index 95616bc..58c3865 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_l.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_l.html
@@ -99,10 +99,10 @@ $(document).ready(function(){initNavTree('functions_l.html','');});
 : <a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">terminus</a>
 </li>
 <li>listen()
-: <a class="el" href="classproton_1_1container.html#acf444f30e25454196894dbee96ba2a44">container</a>
+: <a class="el" href="classproton_1_1container.html#ae234654c72fe7b272728028cd88b8c1c">container</a>
 </li>
 <li>listener()
-: <a class="el" href="classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814">listener</a>
+: <a class="el" href="classproton_1_1listener.html#a3edec85cbcde06b471e8e2fb4726dbf5">listener</a>
 </li>
 </ul>
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_m.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_m.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_m.html
index 9727e65..19be034 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_m.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_m.html
@@ -115,8 +115,14 @@ $(document).ready(function(){initNavTree('functions_m.html','');});
 <li>message()
 : <a class="el" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>
 </li>
+<li>message_annotations()
+: <a class="el" href="classproton_1_1message.html#a05ea365ef83130c85ffbb74498955ca3">message</a>
+</li>
 <li>message_id()
-: <a class="el" href="classproton_1_1message__id.html#a37823024300ef4413ca077df9ddcc4d2">message_id</a>
+: <a class="el" href="classproton_1_1message__id.html#afb6e34ccd03d666d3e5cd4312064c4a3">message_id</a>
+</li>
+<li>MILLISECOND
+: <a class="el" href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">duration</a>
 </li>
 <li>milliseconds()
 : <a class="el" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">duration</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_n.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_n.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_n.html
index eaeb1f9..04765bc 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_n.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_n.html
@@ -95,6 +95,8 @@ $(document).ready(function(){initNavTree('functions_n.html','');});
 <li>name()
 : <a class="el" href="classproton_1_1error__condition.html#a1d89c28bd42ba9a52da008bb69367171">error_condition</a>
 , <a class="el" href="classproton_1_1link.html#a1d89c28bd42ba9a52da008bb69367171">link</a>
+, <a class="el" href="classproton_1_1receiver__options.html#a038ed50e63983958b13e42d49d270b88">receiver_options</a>
+, <a class="el" href="classproton_1_1sender__options.html#af37454934677c6f0e8bbe8bb1087f1ed">sender_options</a>
 </li>
 <li>NEVER
 : <a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">terminus</a>
@@ -119,6 +121,9 @@ $(document).ready(function(){initNavTree('functions_n.html','');});
 <li>now()
 : <a class="el" href="classproton_1_1timestamp.html#a8a432817c74685a518a08ede48d1db34">timestamp</a>
 </li>
+<li>null()
+: <a class="el" href="classproton_1_1null.html#ac6f7583eff281f509c7351b850ad131b">null</a>
+</li>
 <li>numeric_type
 : <a class="el" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">duration</a>
 , <a class="el" href="classproton_1_1timestamp.html#a44829e89515fec974f57f37bbdbfaeb2">timestamp</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_o.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_o.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_o.html
index 2ae1cbd..6983953 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_o.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_o.html
@@ -96,101 +96,104 @@ $(document).ready(function(){initNavTree('functions_o.html','');});
 : <a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda2bc49ec37d6a5715dd23e85f1ff5bb59">sasl</a>
 </li>
 <li>on_accept()
-: <a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">listen_handler</a>
+: <a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">listen_handler</a>
 </li>
 <li>on_close()
 : <a class="el" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">listen_handler</a>
 </li>
 <li>on_connection_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a804f0ea9c2754f143624b4078a61f650">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a8368c2f41b5c1dab4aa063c1c78a6e19">messaging_handler</a>
 </li>
 <li>on_connection_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#aafa83dc2f8f477ba1f76e86dc69cd1e9">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae93110a9bad4868663f37d15cd3139a4">messaging_handler</a>
 </li>
 <li>on_connection_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">messaging_handler</a>
 </li>
 <li>on_connection_wake()
 : <a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481">messaging_handler</a>
 </li>
 <li>on_container_start()
-: <a class="el" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">messaging_handler</a>
 </li>
 <li>on_container_stop()
-: <a class="el" href="classproton_1_1messaging__handler.html#ab5bb8195e26c8818c4f57a734566ecfd">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">messaging_handler</a>
 </li>
 <li>on_delivery_settle()
-: <a class="el" href="classproton_1_1messaging__handler.html#afc96eabc76c471d61627493eadb58ac8">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a4f0e5cebf65a87f301ba5ef82eb8537d">messaging_handler</a>
 </li>
 <li>on_error()
 : <a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">listen_handler</a>
-, <a class="el" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">messaging_handler</a>
+, <a class="el" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">messaging_handler</a>
 </li>
 <li>on_message()
-: <a class="el" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">messaging_handler</a>
+</li>
+<li>on_open()
+: <a class="el" href="classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b">listen_handler</a>
 </li>
 <li>on_receiver_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28">messaging_handler</a>
 </li>
 <li>on_receiver_detach()
-: <a class="el" href="classproton_1_1messaging__handler.html#a93ab65773954cf12eb7f76a26aa44cfe">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a06b10fbf8524545eaf88def91d7235ef">messaging_handler</a>
 </li>
 <li>on_receiver_drain_finish()
-: <a class="el" href="classproton_1_1messaging__handler.html#a815e30c6d10d923d88dc1085b7b0f116">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a0c3ba013a3515fd3d0a1871c984e497e">messaging_handler</a>
 </li>
 <li>on_receiver_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0c281aee5483822bdf4b428834bd7f28">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac0daca9ec2dc45353a04069c6a12f3aa">messaging_handler</a>
 </li>
 <li>on_receiver_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401">messaging_handler</a>
 </li>
 <li>on_sendable()
-: <a class="el" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">messaging_handler</a>
 </li>
 <li>on_sender_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29">messaging_handler</a>
 </li>
 <li>on_sender_detach()
-: <a class="el" href="classproton_1_1messaging__handler.html#a731e7cdbda64b15f069efd560b66ada1">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ae103f0e8f35a8aebfb14b96c298ed938">messaging_handler</a>
 </li>
 <li>on_sender_drain_start()
-: <a class="el" href="classproton_1_1messaging__handler.html#ad3d23a7c3849dabd137610f8ee1569e3">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac07a9aab7eee64a7415f1cacc278344b">messaging_handler</a>
 </li>
 <li>on_sender_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#a2d9d98eee878f1e734457ba01e21228a">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a2347cff02f9ed958ca41fcc31e58d792">messaging_handler</a>
 </li>
 <li>on_sender_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">messaging_handler</a>
 </li>
 <li>on_session_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a54fe4fc5394418f8606f9263f13d2e98">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa3ff10317b9fdcbe00e500cb1e9c96ec">messaging_handler</a>
 </li>
 <li>on_session_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#aca924d2f68649df7945719be3d29a597">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a63bb630e8dc357b22d6c33781c7c6a11">messaging_handler</a>
 </li>
 <li>on_session_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#adddbfd9b7fc7719490bdc21331c42302">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aad43a0028727310bcdbd8f63feb99537">messaging_handler</a>
 </li>
 <li>on_tracker_accept()
-: <a class="el" href="classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a4e61812588fe6fbde253b41f7c02e993">messaging_handler</a>
 </li>
 <li>on_tracker_reject()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0740e8c9ed9d0c304d2adced09802893">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a116c831b8a80727a451ce20c44d781f8">messaging_handler</a>
 </li>
 <li>on_tracker_release()
-: <a class="el" href="classproton_1_1messaging__handler.html#acfde5590c6e826ef9e2c33a28edefe19">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ad107964511dce62449ca730e9b0aca88">messaging_handler</a>
 </li>
 <li>on_tracker_settle()
-: <a class="el" href="classproton_1_1messaging__handler.html#a023a5c57eeeaf79ed5b768cd172ad0ac">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a36620e631024c73f5c6766abf95a8356">messaging_handler</a>
 </li>
 <li>on_transport_close()
-: <a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f">messaging_handler</a>
 </li>
 <li>on_transport_error()
-: <a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665">messaging_handler</a>
 </li>
 <li>on_transport_open()
-: <a class="el" href="classproton_1_1messaging__handler.html#a0c141065eda9a26916ccc63ccea5d3b7">messaging_handler</a>
+: <a class="el" href="classproton_1_1messaging__handler.html#aa68ce0021c22cc956890c6bcc5384b84">messaging_handler</a>
 </li>
 <li>open()
 : <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab">connection</a>
@@ -205,8 +208,8 @@ $(document).ready(function(){initNavTree('functions_o.html','');});
 </li>
 <li>open_sender()
 : <a class="el" href="classproton_1_1connection.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">connection</a>
-, <a class="el" href="classproton_1_1container.html#ace90c31b569a4e5e8b435be43ded9ccb">container</a>
-, <a class="el" href="classproton_1_1session.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">session</a>
+, <a class="el" href="classproton_1_1container.html#ae38864960bb258487b7e0db775243fe9">container</a>
+, <a class="el" href="classproton_1_1session.html#ab997a1233a3327d5ac1e63327fa62717">session</a>
 </li>
 <li>open_session()
 : <a class="el" href="classproton_1_1connection.html#a417060fdeea996b1684bd0fecc6c6420">connection</a>
@@ -224,9 +227,6 @@ $(document).ready(function(){initNavTree('functions_o.html','');});
 <li>operator!()
 : <a class="el" href="classproton_1_1error__condition.html#a61efd4196a96540ee018fee8791f3f10">error_condition</a>
 </li>
-<li>operator()()
-: <a class="el" href="classproton_1_1work.html#a5ccbdeb5350ba8528eab7e4cc49fc68b">work</a>
-</li>
 <li>operator&lt;
 : <a class="el" href="classproton_1_1scalar__base.html#a40bfb9a20944ad3d19f8a90a27a82576">scalar_base</a>
 </li>
@@ -240,7 +240,8 @@ $(document).ready(function(){initNavTree('functions_o.html','');});
 : <a class="el" href="classproton_1_1binary.html#ac04f4568094b18213b75d4400d8e2477">binary</a>
 , <a class="el" href="classproton_1_1connection__options.html#a2c612e142b60cf61ce50d88582465167">connection_options</a>
 , <a class="el" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">duration</a>
-, <a class="el" href="classproton_1_1map.html#a16a75d371d4e6287b352f5066643f030">map&lt; K, T &gt;</a>
+, <a class="el" href="classproton_1_1listener.html#a426fa804e3bb58ef90b29b066c3f5199">listener</a>
+, <a class="el" href="classproton_1_1map.html#ada6de583b7cdc95792661bcc0ff8a517">map&lt; K, T &gt;</a>
 , <a class="el" href="classproton_1_1message.html#ac7abf26f9566b75b59af27ca13b2182f">message</a>
 , <a class="el" href="classproton_1_1message__id.html#a0e4798868734cc90ea4e9ed3ca870d3d">message_id</a>
 , <a class="el" href="classproton_1_1receiver__options.html#a815be8018205013b8ff011d4b62b7324">receiver_options</a>
@@ -258,7 +259,7 @@ $(document).ready(function(){initNavTree('functions_o.html','');});
 : <a class="el" href="classproton_1_1scalar__base.html#a03d4c26cca0115ee1fe1c547e35ec651">scalar_base</a>
 </li>
 <li>operator&gt;&gt;()
-: <a class="el" href="classproton_1_1codec_1_1decoder.html#a92c526a77d6aa412e17051a2cfeb7210">decoder</a>
+: <a class="el" href="classproton_1_1codec_1_1decoder.html#a29037b1d70f61e041b2d5be7c67b577d">decoder</a>
 </li>
 <li>outcome
 : <a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acd">sasl</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_p.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_p.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_p.html
index 24f8379..e4972a1 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_p.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_p.html
@@ -103,13 +103,14 @@ $(document).ready(function(){initNavTree('functions_p.html','');});
 : <a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acdae0a57d717d9f8c8fdba757be1b0afdcf">sasl</a>
 </li>
 <li>port()
-: <a class="el" href="classproton_1_1url.html#a6f16e8b68942ad0d21494d056b4e13d7">url</a>
+: <a class="el" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">listener</a>
+, <a class="el" href="classproton_1_1url.html#a6f16e8b68942ad0d21494d056b4e13d7">url</a>
 </li>
 <li>port_int()
 : <a class="el" href="classproton_1_1url.html#aa54f07362c271f7f550c3f904022329b">url</a>
 </li>
 <li>priority()
-: <a class="el" href="classproton_1_1message.html#a74cc6581e2fa3d3c9f3a885921063b92">message</a>
+: <a class="el" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">message</a>
 </li>
 <li>properties()
 : <a class="el" href="classproton_1_1error__condition.html#ac692ae9e7014e2ef47673c9201a98cf6">error_condition</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_r.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_r.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_r.html
index e5a1162..ae735b5 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_r.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_r.html
@@ -121,7 +121,7 @@ $(document).ready(function(){initNavTree('functions_r.html','');});
 , <a class="el" href="classproton_1_1session.html#a634a0b14e10b9fc50cbb52251c2c8027">session</a>
 </li>
 <li>reconnect()
-: <a class="el" href="classproton_1_1connection__options.html#a5a38fafc56619c03e10979b978393bbc">connection_options</a>
+: <a class="el" href="classproton_1_1connection__options.html#ad053f0ac823eefd100731c1b5248e7e8">connection_options</a>
 </li>
 <li>reconnect_options()
 : <a class="el" href="classproton_1_1reconnect__options.html#ac327dafeb06728192df6cb94dde35edc">reconnect_options</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_s.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_s.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_s.html
index 5383d12..0859700 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_s.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_s.html
@@ -151,7 +151,7 @@ $(document).ready(function(){initNavTree('functions_s.html','');});
 : <a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">terminus</a>
 </li>
 <li>session_options()
-: <a class="el" href="classproton_1_1session__options.html#ad0a94848bc139a7628681a3401402f7b">session_options</a>
+: <a class="el" href="classproton_1_1session__options.html#a2e138875d21432af920338badc26fefb">session_options</a>
 </li>
 <li>sessions()
 : <a class="el" href="classproton_1_1connection.html#a4e6f7ce08bf29e67c7a9823f1ba69561">connection</a>
@@ -176,22 +176,21 @@ $(document).ready(function(){initNavTree('functions_s.html','');});
 , <a class="el" href="classproton_1_1source.html#a6cfde826a3d3092bd8a3a636e2336bbb">source</a>
 </li>
 <li>source_options()
-: <a class="el" href="classproton_1_1source__options.html#a1d2323580261c3bce5c41cb93d72bff9">source_options</a>
+: <a class="el" href="classproton_1_1source__options.html#afb2122d3d1a1f504c7cb23ea1093afcf">source_options</a>
 </li>
 <li>ssl()
-: <a class="el" href="classproton_1_1ssl.html#aab73a626b87b792e31ff0eee531fbcb2">ssl</a>
-, <a class="el" href="classproton_1_1transport.html#a73fe833a759ac581baa889155b7d0633">transport</a>
+: <a class="el" href="classproton_1_1transport.html#a73fe833a759ac581baa889155b7d0633">transport</a>
 </li>
 <li>ssl_certificate()
-: <a class="el" href="classproton_1_1ssl__certificate.html#a8db4264dc2c610f8cc91903610f48361">ssl_certificate</a>
+: <a class="el" href="classproton_1_1ssl__certificate.html#a06065e17b1b4e178adc0047ae99335ac">ssl_certificate</a>
 </li>
 <li>ssl_client_options()
 : <a class="el" href="classproton_1_1connection__options.html#a4eb280b5a62adb5b2075d6316a590c70">connection_options</a>
-, <a class="el" href="classproton_1_1ssl__client__options.html#aaeae243f374927d7729927cb343f8130">ssl_client_options</a>
+, <a class="el" href="classproton_1_1ssl__client__options.html#a05df3dc53e9dc80ed8d90b7724d791b0">ssl_client_options</a>
 </li>
 <li>ssl_server_options()
 : <a class="el" href="classproton_1_1connection__options.html#a5ce3c4591be545f5ae67f22ef64fb9ef">connection_options</a>
-, <a class="el" href="classproton_1_1ssl__server__options.html#a1f181336edbdb677b58eaa1366127da1">ssl_server_options</a>
+, <a class="el" href="classproton_1_1ssl__server__options.html#abf0b30171760149fc5e8dacacbcd0b00">ssl_server_options</a>
 </li>
 <li>state
 : <a class="el" href="classproton_1_1transfer.html#adc6e5733fc3c22f0a7b2914188c49c90">transfer</a>
@@ -210,7 +209,7 @@ $(document).ready(function(){initNavTree('functions_s.html','');});
 : <a class="el" href="classproton_1_1value.html#afdde986e34571c6544abfdea9afdb658">value</a>
 </li>
 <li>symbol()
-: <a class="el" href="classproton_1_1symbol.html#a5d96e10a5b46e6d9a4cc999cbd7c1467">symbol</a>
+: <a class="el" href="classproton_1_1symbol.html#acb24e4da84324613eac952fa3dbdc6a9">symbol</a>
 </li>
 <li>SYS
 : <a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda69a8d053cf3b5b28fa0c7dde6f883e10">sasl</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_vars.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_vars.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_vars.html
index b3c4344..83f5ce5 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_vars.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_vars.html
@@ -109,6 +109,9 @@ $(document).ready(function(){initNavTree('functions_vars.html','');});
 <li>IMMEDIATE
 : <a class="el" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">duration</a>
 </li>
+<li>MILLISECOND
+: <a class="el" href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">duration</a>
+</li>
 <li>MINUTE
 : <a class="el" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">duration</a>
 </li>


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


[23/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/type__compat_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/type__compat_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/type__compat_8h_source.html
index 9b6286f..ba8aad1 100755
--- a/content/releases/qpid-proton-master/proton/c/api/type__compat_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/type__compat_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/type_compat.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('type__compat_8h_source.html','');});
 <div class="title">type_compat.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TYPE_COMPAT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TYPE_COMPAT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"
 ><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014
 "></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="l
 ineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="comment">// Get Boolean</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#if !defined(__cplusplus) &amp;&amp; !defined(__bool_true_false_are_defined)</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor"># if
  __STDC_VERSION__ &gt;= 199901L || __GNUC__ &gt;= 3 || _MSC_VER &gt;=1800</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#  include &lt;stdbool.h&gt;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor"># else</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">// Need to get bool/true/false manually</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#  if _MSC_VER</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#   define bool char</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#   define false 0</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span
  class="preprocessor">#   define true 1</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#   define __bool_true_false_are_defined</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#  else</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#   error &quot;No definitions for bool/true/false&quot;</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="comment">/*</span></di
 v><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="comment"> * Handle special cases for stdint.h and the definition for ssize_t.</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="comment"> * Third party libraries (e.g. Boost) may provide competing solutions.</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="comment"> * The effects of this include file may be controlled by overrides:</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="comment"> *  PN_DEFINE_STDINT/PN_NODEFINE_STDINT   : turn on/off definition of int64_t etc.</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment"> *  PN_DEFINE_SSIZE_T/PN_NODEFINE_SSIZE_T
  : turn on/off definition of ssize_t</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="comment"> *  PN_INCLUDE_STDINT/PN_NOINCLUDE_STDINT : include (or not) stdint.h</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="comment">// Honor positive overrides</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#if defined(PN_DEFINE_STDINT)</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor"># define PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#endif</span></div><div class=
 "line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#if defined(PN_INCLUDE_STDINT)</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor"># define PNI_INCLUDE_STDINT)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#if defined(PN_DEFINE_SSIZE_T)</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor"># define PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class
 ="comment">// Determinine default action</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#ifndef _MSC_VER</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="comment">// Not Windows and not using Visual Studio</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="comment">/* MBED_BUILD_TIMESTAMP is used to detect whether Proton is being built on www.mbed.org with</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="comment">the ARM compiler. In that case ssize_t needs to be defined in this file. */</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#if defined(MBED_BUILD_TIMESTAMP)</span></div><div class="line"><a name="
 l00073"></a><span class="lineno">   73</span>&#160;<span class="preprocessor">#  define PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#include &lt;sys/types.h&gt;</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* defined(MBED_LIBRARY_VERSION) */</span><span class="preprocessor"></span></div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor"># ifndef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#  define PNI_INCLUDE_STDINT</span></div><div class=
 "line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="comment">// all versions of Visual Studio</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor"># ifndef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="comment">// ssize_t def is needed, unless third party definition interferes, e.g. python/swig</span></div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">#  ifndef Py_CONFIG_H</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">#   define PNI_DEFINE_SSIZE_T
 </span></div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor"># if (_MSC_VER &lt; 1600)</span></div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="comment">// VS 2008 and earlier</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="preprocessor">#  ifndef PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="preprocessor">#   define PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;<s
 pan class="preprocessor">#  endif</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor"># else</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="comment">// VS 2010 and newer</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="preprocessor">#  ifndef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">#   define PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;<span class="preprocessor"># endif // (_MSC_VER &lt; 1600)</span></div><div class="line"><a name="l00102"></a><sp
 an class="lineno">  102</span>&#160;<span class="preprocessor">#endif //_MSC_VER</span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;<span class="comment">// Honor negative overrides</span></div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="preprocessor">#ifdef PN_NODEFINE_SSIZE_T</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor"># undef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;<span class="preprocessor">#ifdef PN_NODEFINE_STDINT</span></div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="preprocessor"># undef PNI_DEFINE_S
 TDINT</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">#ifdef PN_NOINCLUDE_STDINT</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor"># undef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">#ifdef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor"># include &lt;stdint.h&gt;</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>
 &#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">#ifdef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor"># ifdef _MSC_VER</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;<span class="preprocessor">#  include &lt;BaseTsd.h&gt;</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;<span class="keyword">typedef</span> SSIZE_T ssize_t;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<span class="preprocessor"># else</span></div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="keyword">typedef</span> intptr_t ssize_t;</div><div class="line"><a name="l00125"></a>
 <span class="lineno">  125</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">#endif // PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#ifdef PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor"># ifdef _MSC_VER</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int8 int8_t;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signe
 d</span> __int16 int16_t;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int32 int32_t;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int64 int64_t;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int8 uint8_t;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int16 uint16_t;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int32 uint3
 2_t;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int64 uint64_t;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="preprocessor"># else // _MSC_VER</span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;<span class="preprocessor">#  error stdint.h definitions not kown</span></div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;<span class="preprocessor">#endif // PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#16
 0;<span class="preprocessor">#endif </span><span class="comment">/* type_compat.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents -->
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_TYPE_COMPAT_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_TYPE_COMPAT_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"
 ><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014
 "></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="l
 ineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="comment">/* Get Boolean */</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#if !defined(__cplusplus) &amp;&amp; !defined(__bool_true_false_are_defined)</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#
  if __STDC_VERSION__ &gt;= 199901L || __GNUC__ &gt;= 3 || _MSC_VER &gt;=1800</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#  include &lt;stdbool.h&gt;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor"># else</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">/* Need to get bool/true/false manually */</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="preprocessor">#  if _MSC_VER</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#   define bool char</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#   define false 0</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160
 ;<span class="preprocessor">#   define true 1</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#   define __bool_true_false_are_defined</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#  else</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#   error &quot;No definitions for bool/true/false&quot;</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="comment">/*</spa
 n></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="comment"> * Handle special cases for stdint.h and the definition for ssize_t.</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="comment"> * Third party libraries (e.g. Boost) may provide competing solutions.</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="comment"> * The effects of this include file may be controlled by overrides:</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="comment"> *  PN_DEFINE_STDINT/PN_NODEFINE_STDINT   : turn on/off definition of int64_t etc.</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment"> *  PN_DEFINE_SSIZE_T/PN_NODEFINE_S
 SIZE_T : turn on/off definition of ssize_t</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="comment"> *  PN_INCLUDE_STDINT/PN_NOINCLUDE_STDINT : include (or not) stdint.h</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="comment">/* Honor positive overrides */</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#if defined(PN_DEFINE_STDINT)</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor"># define PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#endif</span></div><d
 iv class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#if defined(PN_INCLUDE_STDINT)</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor"># define PNI_INCLUDE_STDINT)</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#if defined(PN_DEFINE_SSIZE_T)</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor"># define PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<s
 pan class="comment">/* Determine default action */</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#ifndef _MSC_VER</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="comment">/* Not Windows and not using Visual Studio */</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="comment">/* MBED_BUILD_TIMESTAMP is used to detect whether Proton is being built on www.mbed.org with</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="comment">the ARM compiler. In that case ssize_t needs to be defined in this file. */</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#if defined(MBED_BUILD_TIMESTAMP)</span></div><div class="li
 ne"><a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="preprocessor">#  define PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#include &lt;sys/types.h&gt;</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* defined(MBED_LIBRARY_VERSION) */</span><span class="preprocessor"></span></div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor"># ifndef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#  define PNI_INCLUDE_STDINT</span></di
 v><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="comment">/* all versions of Visual Studio */</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor"># ifndef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="comment">/* ssize_t def is needed, unless third party definition interferes, e.g. python/swig */</span></div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span class="preprocessor">#  ifndef Py_CONFIG_H</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">#   define
  PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor"># if (_MSC_VER &lt; 1600)</span></div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="comment">/* VS 2008 and earlier */</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="preprocessor">#  ifndef PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="preprocessor">#   define PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00094"></a><span class="lineno
 ">   94</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor"># else</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="comment">/* VS 2010 and newer */</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="preprocessor">#  ifndef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">#   define PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">#  endif</span></div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;<span class="preprocessor"># endif </span><span class="comment">/* (_MSC_VER &lt; 1600) 
 */</span><span class="preprocessor"></span></div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/*_MSC_VER */</span><span class="preprocessor"></span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;<span class="comment">/* Honor negative overrides */</span></div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="preprocessor">#ifdef PN_NODEFINE_SSIZE_T</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor"># undef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;<span class="preprocessor">#if
 def PN_NODEFINE_STDINT</span></div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="preprocessor"># undef PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">#ifdef PN_NOINCLUDE_STDINT</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor"># undef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">#ifdef PNI_INCLUDE_STDINT</span></div><div class="line"><a name="l00116"></a><span class="line
 no">  116</span>&#160;<span class="preprocessor"># include &lt;stdint.h&gt;</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">#ifdef PNI_DEFINE_SSIZE_T</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor"># ifdef _MSC_VER</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;<span class="preprocessor">#  include &lt;BaseTsd.h&gt;</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;<span class="keyword">typedef</span> SSIZE_T ssize_t;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;<span class="preprocessor"># else</span></div><div class="line"
 ><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="keyword">typedef</span> intptr_t ssize_t;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor"># endif</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* PNI_DEFINE_SSIZE_T */</span><span class="preprocessor"></span></div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#ifdef PNI_DEFINE_STDINT</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor"># ifdef _MSC_VER</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;<span class="keyw
 ord">typedef</span> <span class="keywordtype">signed</span> __int8 int8_t;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int16 int16_t;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int32 int32_t;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">signed</span> __int64 int64_t;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int8 uint8_t;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;<span class="keyword">typedef</span> <span cla
 ss="keywordtype">unsigned</span> __int16 uint16_t;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int32 uint32_t;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int64 uint64_t;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="preprocessor"># else </span><span class="comment">/* _MSC_VER */</span><span class="preprocessor"></span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;<span class="preprocessor">#  error stdint.h definitions not kown</span></div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;<span class="preprocessor"># endif</span></div><div class="li
 ne"><a name="l00144"></a><span class="lineno">  144</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* PNI_DEFINE_SSIZE_T */</span><span class="preprocessor"></span></div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* type_compat.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
@@ -101,7 +101,7 @@ $(document).ready(function(){initNavTree('type__compat_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>type_compat.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>


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


[13/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/config_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/config_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/config_8hpp_source.html
index e5999a6..7223db3 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/config_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/config_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('config_8hpp_source.html','');});
 <div class="title">config.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div cl
 ass="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a na
 me="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><spa
 n class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#if d
 efined(__cplusplus) &amp;&amp; __cplusplus &gt;= 201103</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_CPP11 1</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_CPP11 0</span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_SHARED_PTR</span></div><div class="line"><a name="l00045"></a>
 <span class="lineno">   45</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_SHARED_PTR PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_UNIQUE_PTR</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_UNIQUE_PTR PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_LONG_LONG</span></div
 ><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_LONG_LONG PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_NULLPTR</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_NULLPTR PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#ifndef
  PN_CPP_HAS_RVALUE_REFERENCES</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_RVALUE_REFERENCES PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_OVERRIDE</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_OVERRIDE PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno"> 
   68</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_OVERRIDE</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#define PN_CPP_OVERRIDE override</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="preprocessor">#define PN_CPP_OVERRIDE</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_EXPLICIT_CONVERSIONS</span></div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_EXPLICIT_CONVE
 RSIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_DEFAULTED_FUNCTIONS</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_DEFAULTED_FUNCTIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_DELETED_FUNCTIONS</span></div><div class="line"><a name="l00083"></a><span class="lineno">  
  83</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_DELETED_FUNCTIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_THREAD_LOCAL</span></div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_THREAD_LOCAL PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_FUNCTION</span></div><div cla
 ss="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_FUNCTION PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_BIND</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_BIND PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">#ifndef PN_
 CPP_HAS_CHRONO</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_CHRONO PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_RANDOM</span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_RANDOM PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="
 preprocessor">#ifndef PN_CPP_HAS_STD_MUTEX</span></div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_MUTEX PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_ATOMIC</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_ATOMIC PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00114"></a><span class="
 lineno">  114</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_THREAD</span></div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_THREAD PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;<span class="preprocessor">#endif // PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div></div><!-- fragment --></div><!-- contents -->
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div cl
 ass="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a na
 me="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><spa
 n class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="comment">// Read library compilation presets -</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="comment">//
  This sets the options the library itself was compiled with</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="comment">// and sets up the compilation options is we are compiling the library itself</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="preprocessor">#include &quot;config_presets.hpp&quot;</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="preprocessor">#define PN_CPP_SUPPORTS_THREADS PN_CPP_LIB_HAS_CPP11 || (PN_CPP_LIB_HAS_STD_THREAD &amp;&amp; PN_CPP_LIB_HAS_STD_MUTEX)</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="preprocessor">#if defined(__clang__) &amp;&amp; defined(__apple_build_version__) &
 amp;&amp; ((__clang_major__ * 100) + __clang_minor__) &gt;= 301</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="preprocessor">#if __has_feature(cxx_thread_local)</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_THREAD_LOCAL 1</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_THREAD_LOCAL 0</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class=
 "line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="preprocessor">#if defined(__cplusplus) &amp;&amp; __cplusplus &gt;= 201103</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_CPP11 1</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_CPP11 0</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l0
 0062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_LONG_LONG_TYPE</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_LONG_LONG_TYPE PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_NULLPTR</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_NULLPTR PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#endi
 f</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_RVALUE_REFERENCES</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_RVALUE_REFERENCES PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_OVERRIDE</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_OVERRIDE PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00077"></a><span class="lineno"
 >   77</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_OVERRIDE</span></div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">#define PN_CPP_OVERRIDE override</span></div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span class="preprocessor">#define PN_CPP_OVERRIDE</span></div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;<span c
 lass="preprocessor">#ifndef PN_CPP_HAS_EXPLICIT_CONVERSIONS</span></div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_EXPLICIT_CONVERSIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_DEFAULTED_FUNCTIONS</span></div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_DEFAULTED_FUNCTIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;</div><div c
 lass="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_DEFAULTED_MOVE_INITIALIZERS</span></div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_DEFAULTED_MOVE_INITIALIZERS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_DELETED_FUNCTIONS</span></div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_DELETED_FUNCTIONS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;<span class="preprocessor">#endif</span></div><
 div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_THREAD_LOCAL</span></div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_THREAD_LOCAL PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_VARIADIC_TEMPLATES</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_VARIADIC_TEMPLATES PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00107"></a><span class="lineno">  10
 7</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_LAMBDAS</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_LAMBDAS PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;<span class="comment">// Library features</span></div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_
 HEADER_RANDOM</span></div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_HEADER_RANDOM PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_UNIQUE_PTR</span></div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_UNIQUE_PTR PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</sp
 an>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_MUTEX</span></div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_MUTEX PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_ATOMIC</span></div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_ATOMIC PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00
 131"></a><span class="lineno">  131</span>&#160;<span class="preprocessor">#ifndef PN_CPP_HAS_STD_THREAD</span></div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;<span class="preprocessor">#define PN_CPP_HAS_STD_THREAD PN_CPP_HAS_CPP11</span></div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;<span class="preprocessor">#endif // PROTON_INTERNAL_CONFIG_HPP</span></div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;</div></div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/connection_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/connection_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/connection_8hpp_source.html
index 42f4ac6..916ce96 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/connection_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/connection_8hpp_source.html
@@ -93,17 +93,17 @@ $(document).ready(function(){initNavTree('connection_8hpp_source.html','');});
 <div class="title">connection.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="connection_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributo
 r license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#16
 0;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License f
 or the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div clas
 s="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/object.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="endpoint_8hpp.html">./endpoint.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="session_8hpp.html">./session.hpp</a>&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include &lt;string&gt
 ;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">struct </span>pn_connection_t;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno"><a class="line" href="classproton_1_1connection.html">   43</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1connection.html">conn
 ection</a> : <span class="keyword">public</span> internal::object&lt;pn_connection_t&gt;, <span class="keyword">public</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection.html">connection</a>(pn_connection_t* c) : internal::object&lt;pn_connection_t&gt;(c) {}</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="classproton_1_1connection.html#a7fa48f6882eccec91ea9c433e1ad2a57">   51</a></span>&#160;    <a class="code" href="classproton_1_1connection.html#a7fa48f6882eccec91ea9c433e1ad2a57">connection</a>() : internal::object&lt;pn_connection_t&gt;(0) {}</div><div class="line"><a na
 me="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</span>;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> active() <span class="keyword">const</span>;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> closed() <span class="keyword">const</span>;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const;</div><div class="line"><a name="l00058"></a><span class="lineno">  
  58</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>&amp; <a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>&amp; <a class="code" href="classproton_1_1work__queue.html">work_queue</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1transpo
 rt.html">transport</a> transport() const;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN std::string virtual_host() <span class="keyword">const</span>;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    PN_CPP_EXTERN std::string container_id() <span class="keyword">const</span>;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN std::string user() <span class="keyword">const</span>;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</sp
 an> open();</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> open(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp;);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close();</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00093"></a><s
 pan class="lineno">   93</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> open_session();</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> open_session(<span class="keyword">const</span> <a class="code" href="classproton_1_1session__options.html">session_options</a>&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> default_session();</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;    PN_CPP_EXTERN <a class="code" href="classp
 roton_1_1sender.html">sender</a> open_sender(<span class="keyword">const</span> std::string&amp; addr);</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1sender.html">sender</a> open_sender(<span class="keyword">const</span> std::string&amp; addr, <span class="keyword">const</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1receiver.html">receiver</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span 
 class="lineno">  112</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1receiver.html">receiver</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr,</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;                                         <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">receiver_options</a>&amp;);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1sender__options.html">sender_options</a> sender_options() const;</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" hre
 f="classproton_1_1receiver__options.html">receiver_options</a> receiver_options() const;</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN session_range sessions() <span class="keyword">const</span>;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;    PN_CPP_EXTERN receiver_range receivers() <span class="keyword">const</span>;</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN sender_range senders() <span class="keyword">const</span>;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;   
  PN_CPP_EXTERN uint32_t max_frame_size() <span class="keyword">const</span>;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;    PN_CPP_EXTERN uint16_t max_sessions() <span class="keyword">const</span>;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;    PN_CPP_EXTERN uint32_t idle_timeout() <span class="keyword">const</span>;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> wake() <span class="keyword">const</span>;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#1
 60;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;connection&gt;;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>container;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;};</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;<span class="preprocessor">#endif // PROTON_CONNECTION_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of co
 nnections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<a href="connection_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CONNECTION_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CONNECTION_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributo
 r license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#16
 0;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License f
 or the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div clas
 s="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;./internal/object.hpp&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="endpoint_8hpp.html">./endpoint.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="session_8hpp.html">./session.hpp</a>&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="preprocessor">#include &lt;string&gt
 ;</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">struct </span>pn_connection_t;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno"><a class="line" href="classproton_1_1connection.html">   43</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1connection.html">conn
 ection</a> : <span class="keyword">public</span> internal::object&lt;pn_connection_t&gt;, <span class="keyword">public</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1connection.html">connection</a>(pn_connection_t* c) : internal::object&lt;pn_connection_t&gt;(c) {}</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="classproton_1_1connection.html#a7fa48f6882eccec91ea9c433e1ad2a57">   51</a></span>&#160;    <a class="code" href="classproton_1_1connection.html#a7fa48f6882eccec91ea9c433e1ad2a57">connection</a>() : internal::object&lt;pn_connection_t&gt;(0) {}</div><div class="line"><a na
 me="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</span>;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> active() <span class="keyword">const</span>;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> closed() <span class="keyword">const</span>;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const;</div><div class="line"><a name="l00058"></a><span class="lineno">  
  58</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>&amp; <a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>&amp; <a class="code" href="classproton_1_1work__queue.html">work_queue</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1transpo
 rt.html">transport</a> transport() const;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN std::string virtual_host() <span class="keyword">const</span>;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    PN_CPP_EXTERN std::string container_id() <span class="keyword">const</span>;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN std::string user() <span class="keyword">const</span>;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</sp
 an> open();</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> open(<span class="keyword">const</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a>&amp;);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close();</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00093"></a><s
 pan class="lineno">   93</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> open_session();</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> open_session(<span class="keyword">const</span> <a class="code" href="classproton_1_1session__options.html">session_options</a>&amp;);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1session.html">session</a> default_session();</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;    PN_CPP_EXTERN <a class="code" href="classp
 roton_1_1sender.html">sender</a> open_sender(<span class="keyword">const</span> std::string&amp; addr);</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1sender.html">sender</a> open_sender(<span class="keyword">const</span> std::string&amp; addr, <span class="keyword">const</span> <a class="code" href="classproton_1_1sender__options.html">sender_options</a>&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1receiver.html">receiver</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span 
 class="lineno">  112</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1receiver.html">receiver</a> open_receiver(<span class="keyword">const</span> std::string&amp; addr,</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;                                         <span class="keyword">const</span> <a class="code" href="classproton_1_1receiver__options.html">receiver_options</a>&amp;);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1sender__options.html">sender_options</a> sender_options() const;</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" hre
 f="classproton_1_1receiver__options.html">receiver_options</a> receiver_options() const;</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN session_range sessions() <span class="keyword">const</span>;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;    PN_CPP_EXTERN receiver_range receivers() <span class="keyword">const</span>;</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN sender_range senders() <span class="keyword">const</span>;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;   
  PN_CPP_EXTERN uint32_t max_frame_size() <span class="keyword">const</span>;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;    PN_CPP_EXTERN uint16_t max_sessions() <span class="keyword">const</span>;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;    PN_CPP_EXTERN uint32_t idle_timeout() <span class="keyword">const</span>;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> wake() <span class="keyword">const</span>;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#1
 60;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;connection&gt;;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>container;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;};</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;<span class="preprocessor">#endif // PROTON_CONNECTION_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of co
 nnections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1sender_html"><div class="ttname"><a href="classproton_1_1sender.html">proton::sender</a></div><div class="ttdoc">A channel for sending messages. </div><div class="ttdef"><b>Definition:</b> sender.hpp:39</div></div>
-<div class="ttc" id="classproton_1_1sender__options_html"><div class="ttname"><a href="classproton_1_1sender__options.html">proton::sender_options</a></div><div class="ttdoc">Options for creating a sender. </div><div class="ttdef"><b>Definition:</b> sender_options.hpp:56</div></div>
+<div class="ttc" id="classproton_1_1sender__options_html"><div class="ttname"><a href="classproton_1_1sender__options.html">proton::sender_options</a></div><div class="ttdoc">Options for creating a sender. </div><div class="ttdef"><b>Definition:</b> sender_options.hpp:57</div></div>
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1connection_html"><div class="ttname"><a href="classproton_1_1connection.html">proton::connection</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div><div class="ttdef"><b>Definition:</b> connection.hpp:43</div></div>
-<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:65</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:66</div></div>
 <div class="ttc" id="classproton_1_1endpoint_html"><div class="ttname"><a href="classproton_1_1endpoint.html">proton::endpoint</a></div><div class="ttdoc">The base class for session, connection, and link. </div><div class="ttdef"><b>Definition:</b> endpoint.hpp:36</div></div>
 <div class="ttc" id="classproton_1_1session_html"><div class="ttname"><a href="classproton_1_1session.html">proton::session</a></div><div class="ttdoc">A container of senders and receivers. </div><div class="ttdef"><b>Definition:</b> session.hpp:41</div></div>
-<div class="ttc" id="classproton_1_1receiver__options_html"><div class="ttname"><a href="classproton_1_1receiver__options.html">proton::receiver_options</a></div><div class="ttdoc">Options for creating a receiver. </div><div class="ttdef"><b>Definition:</b> receiver_options.hpp:55</div></div>
+<div class="ttc" id="classproton_1_1receiver__options_html"><div class="ttname"><a href="classproton_1_1receiver__options.html">proton::receiver_options</a></div><div class="ttdoc">Options for creating a receiver. </div><div class="ttdef"><b>Definition:</b> receiver_options.hpp:56</div></div>
 <div class="ttc" id="classproton_1_1receiver_html"><div class="ttname"><a href="classproton_1_1receiver.html">proton::receiver</a></div><div class="ttdoc">A channel for receiving messages. </div><div class="ttdef"><b>Definition:</b> receiver.hpp:40</div></div>
-<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:94</div></div>
+<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:339</div></div>
 <div class="ttc" id="classproton_1_1connection_html_a7fa48f6882eccec91ea9c433e1ad2a57"><div class="ttname"><a href="classproton_1_1connection.html#a7fa48f6882eccec91ea9c433e1ad2a57">proton::connection::connection</a></div><div class="ttdeci">connection()</div><div class="ttdoc">Create an empty connection. </div><div class="ttdef"><b>Definition:</b> connection.hpp:51</div></div>
 <div class="ttc" id="session_8hpp_html"><div class="ttname"><a href="session_8hpp.html">session.hpp</a></div><div class="ttdoc">A container of senders and receivers. </div></div>
 <div class="ttc" id="classproton_1_1transport_html"><div class="ttname"><a href="classproton_1_1transport.html">proton::transport</a></div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> transport.hpp:37</div></div>


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


[16/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.html
index d5bf2d5..432089e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.html
@@ -104,120 +104,120 @@ $(document).ready(function(){initNavTree('classproton_1_1messaging__handler.html
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
-<tr class="memitem:a4949b0c93402fae0c07492d984688a25"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a> (<a class="el" href="classproton_1_1container.html">container</a> &amp;c)</td></tr>
-<tr class="memdesc:a4949b0c93402fae0c07492d984688a25"><td class="mdescLeft">&#160;</td><td class="mdescRight">The container event loop is starting.  <a href="#a4949b0c93402fae0c07492d984688a25">More...</a><br /></td></tr>
-<tr class="separator:a4949b0c93402fae0c07492d984688a25"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ab5bb8195e26c8818c4f57a734566ecfd"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ab5bb8195e26c8818c4f57a734566ecfd">on_container_stop</a> (<a class="el" href="classproton_1_1container.html">container</a> &amp;c)</td></tr>
-<tr class="memdesc:ab5bb8195e26c8818c4f57a734566ecfd"><td class="mdescLeft">&#160;</td><td class="mdescRight">The container event loop is stopping.  <a href="#ab5bb8195e26c8818c4f57a734566ecfd">More...</a><br /></td></tr>
-<tr class="separator:ab5bb8195e26c8818c4f57a734566ecfd"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a96879b0b0b7ade11f98d3f450abd4c46"><td class="memItemLeft" align="right" valign="top"><a id="a96879b0b0b7ade11f98d3f450abd4c46"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a> (<a class="el" href="classproton_1_1delivery.html">delivery</a> &amp;d, <a class="el" href="classproton_1_1message.html">message</a> &amp;m)</td></tr>
-<tr class="memdesc:a96879b0b0b7ade11f98d3f450abd4c46"><td class="mdescLeft">&#160;</td><td class="mdescRight">A message is received. <br /></td></tr>
-<tr class="separator:a96879b0b0b7ade11f98d3f450abd4c46"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:aa24f522a68cdf382762702cece7790e7"><td class="memItemLeft" align="right" valign="top"><a id="aa24f522a68cdf382762702cece7790e7"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;s)</td></tr>
-<tr class="memdesc:aa24f522a68cdf382762702cece7790e7"><td class="mdescLeft">&#160;</td><td class="mdescRight">A message can be sent. <br /></td></tr>
-<tr class="separator:aa24f522a68cdf382762702cece7790e7"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a0c141065eda9a26916ccc63ccea5d3b7"><td class="memItemLeft" align="right" valign="top"><a id="a0c141065eda9a26916ccc63ccea5d3b7"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a0c141065eda9a26916ccc63ccea5d3b7">on_transport_open</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;t)</td></tr>
-<tr class="memdesc:a0c141065eda9a26916ccc63ccea5d3b7"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport is open. <br /></td></tr>
-<tr class="separator:a0c141065eda9a26916ccc63ccea5d3b7"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a47c33c5e6c13d23f1b8a745bf7bdfa8f"><td class="memItemLeft" align="right" valign="top"><a id="a47c33c5e6c13d23f1b8a745bf7bdfa8f"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f">on_transport_close</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;t)</td></tr>
-<tr class="memdesc:a47c33c5e6c13d23f1b8a745bf7bdfa8f"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport has closed. <br /></td></tr>
-<tr class="separator:a47c33c5e6c13d23f1b8a745bf7bdfa8f"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:af89551ce0e44ae3465d4b078f1c87653"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653">on_transport_error</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;t)</td></tr>
-<tr class="memdesc:af89551ce0e44ae3465d4b078f1c87653"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport has closed with an error condition.  <a href="#af89551ce0e44ae3465d4b078f1c87653">More...</a><br /></td></tr>
-<tr class="separator:af89551ce0e44ae3465d4b078f1c87653"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a16ba022e899957b2e25b9561b1f53968"><td class="memItemLeft" align="right" valign="top"><a id="a16ba022e899957b2e25b9561b1f53968"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">on_connection_open</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;c)</td></tr>
-<tr class="memdesc:a16ba022e899957b2e25b9561b1f53968"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the connection. <br /></td></tr>
-<tr class="separator:a16ba022e899957b2e25b9561b1f53968"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a804f0ea9c2754f143624b4078a61f650"><td class="memItemLeft" align="right" valign="top"><a id="a804f0ea9c2754f143624b4078a61f650"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a804f0ea9c2754f143624b4078a61f650">on_connection_close</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;c)</td></tr>
-<tr class="memdesc:a804f0ea9c2754f143624b4078a61f650"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the connection. <br /></td></tr>
-<tr class="separator:a804f0ea9c2754f143624b4078a61f650"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:aafa83dc2f8f477ba1f76e86dc69cd1e9"><td class="memItemLeft" align="right" valign="top"><a id="aafa83dc2f8f477ba1f76e86dc69cd1e9"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aafa83dc2f8f477ba1f76e86dc69cd1e9">on_connection_error</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;c)</td></tr>
-<tr class="memdesc:aafa83dc2f8f477ba1f76e86dc69cd1e9"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the connection with an error condition. <br /></td></tr>
-<tr class="separator:aafa83dc2f8f477ba1f76e86dc69cd1e9"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:adddbfd9b7fc7719490bdc21331c42302"><td class="memItemLeft" align="right" valign="top"><a id="adddbfd9b7fc7719490bdc21331c42302"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#adddbfd9b7fc7719490bdc21331c42302">on_session_open</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;s)</td></tr>
-<tr class="memdesc:adddbfd9b7fc7719490bdc21331c42302"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the session. <br /></td></tr>
-<tr class="separator:adddbfd9b7fc7719490bdc21331c42302"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a54fe4fc5394418f8606f9263f13d2e98"><td class="memItemLeft" align="right" valign="top"><a id="a54fe4fc5394418f8606f9263f13d2e98"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a54fe4fc5394418f8606f9263f13d2e98">on_session_close</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;s)</td></tr>
-<tr class="memdesc:a54fe4fc5394418f8606f9263f13d2e98"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the session. <br /></td></tr>
-<tr class="separator:a54fe4fc5394418f8606f9263f13d2e98"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:aca924d2f68649df7945719be3d29a597"><td class="memItemLeft" align="right" valign="top"><a id="aca924d2f68649df7945719be3d29a597"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aca924d2f68649df7945719be3d29a597">on_session_error</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;s)</td></tr>
-<tr class="memdesc:aca924d2f68649df7945719be3d29a597"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the session with an error condition. <br /></td></tr>
-<tr class="separator:aca924d2f68649df7945719be3d29a597"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a768b0a50669aa1d512d12e9d68af14cd"><td class="memItemLeft" align="right" valign="top"><a id="a768b0a50669aa1d512d12e9d68af14cd"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd">on_receiver_open</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;l)</td></tr>
-<tr class="memdesc:a768b0a50669aa1d512d12e9d68af14cd"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the link. <br /></td></tr>
-<tr class="separator:a768b0a50669aa1d512d12e9d68af14cd"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a93ab65773954cf12eb7f76a26aa44cfe"><td class="memItemLeft" align="right" valign="top"><a id="a93ab65773954cf12eb7f76a26aa44cfe"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a93ab65773954cf12eb7f76a26aa44cfe">on_receiver_detach</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;l)</td></tr>
-<tr class="memdesc:a93ab65773954cf12eb7f76a26aa44cfe"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer detached the link. <br /></td></tr>
-<tr class="separator:a93ab65773954cf12eb7f76a26aa44cfe"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a77ac5c1fd05404728451cd06dee1c907"><td class="memItemLeft" align="right" valign="top"><a id="a77ac5c1fd05404728451cd06dee1c907"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907">on_receiver_close</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;l)</td></tr>
-<tr class="memdesc:a77ac5c1fd05404728451cd06dee1c907"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link. <br /></td></tr>
-<tr class="separator:a77ac5c1fd05404728451cd06dee1c907"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a0c281aee5483822bdf4b428834bd7f28"><td class="memItemLeft" align="right" valign="top"><a id="a0c281aee5483822bdf4b428834bd7f28"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a0c281aee5483822bdf4b428834bd7f28">on_receiver_error</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;l)</td></tr>
-<tr class="memdesc:a0c281aee5483822bdf4b428834bd7f28"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link with an error condition. <br /></td></tr>
-<tr class="separator:a0c281aee5483822bdf4b428834bd7f28"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a0b5d066e5463d3365f662c8a7dc52661"><td class="memItemLeft" align="right" valign="top"><a id="a0b5d066e5463d3365f662c8a7dc52661"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">on_sender_open</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;l)</td></tr>
-<tr class="memdesc:a0b5d066e5463d3365f662c8a7dc52661"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the link. <br /></td></tr>
-<tr class="separator:a0b5d066e5463d3365f662c8a7dc52661"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a731e7cdbda64b15f069efd560b66ada1"><td class="memItemLeft" align="right" valign="top"><a id="a731e7cdbda64b15f069efd560b66ada1"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a731e7cdbda64b15f069efd560b66ada1">on_sender_detach</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;l)</td></tr>
-<tr class="memdesc:a731e7cdbda64b15f069efd560b66ada1"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer detached the link. <br /></td></tr>
-<tr class="separator:a731e7cdbda64b15f069efd560b66ada1"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a7942b98699bd21e827041626ee1b5c84"><td class="memItemLeft" align="right" valign="top"><a id="a7942b98699bd21e827041626ee1b5c84"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84">on_sender_close</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;l)</td></tr>
-<tr class="memdesc:a7942b98699bd21e827041626ee1b5c84"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link. <br /></td></tr>
-<tr class="separator:a7942b98699bd21e827041626ee1b5c84"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a2d9d98eee878f1e734457ba01e21228a"><td class="memItemLeft" align="right" valign="top"><a id="a2d9d98eee878f1e734457ba01e21228a"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a2d9d98eee878f1e734457ba01e21228a">on_sender_error</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;l)</td></tr>
-<tr class="memdesc:a2d9d98eee878f1e734457ba01e21228a"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link with an error condition. <br /></td></tr>
-<tr class="separator:a2d9d98eee878f1e734457ba01e21228a"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a003afbb57c00ce404a863152db7867ad"><td class="memItemLeft" align="right" valign="top"><a id="a003afbb57c00ce404a863152db7867ad"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad">on_tracker_accept</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;d)</td></tr>
-<tr class="memdesc:a003afbb57c00ce404a863152db7867ad"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer accepted a transfer. <br /></td></tr>
-<tr class="separator:a003afbb57c00ce404a863152db7867ad"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a0740e8c9ed9d0c304d2adced09802893"><td class="memItemLeft" align="right" valign="top"><a id="a0740e8c9ed9d0c304d2adced09802893"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a0740e8c9ed9d0c304d2adced09802893">on_tracker_reject</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;d)</td></tr>
-<tr class="memdesc:a0740e8c9ed9d0c304d2adced09802893"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer rejected a transfer. <br /></td></tr>
-<tr class="separator:a0740e8c9ed9d0c304d2adced09802893"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:acfde5590c6e826ef9e2c33a28edefe19"><td class="memItemLeft" align="right" valign="top"><a id="acfde5590c6e826ef9e2c33a28edefe19"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#acfde5590c6e826ef9e2c33a28edefe19">on_tracker_release</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;d)</td></tr>
-<tr class="memdesc:acfde5590c6e826ef9e2c33a28edefe19"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer released a transfer. <br /></td></tr>
-<tr class="separator:acfde5590c6e826ef9e2c33a28edefe19"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a023a5c57eeeaf79ed5b768cd172ad0ac"><td class="memItemLeft" align="right" valign="top"><a id="a023a5c57eeeaf79ed5b768cd172ad0ac"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a023a5c57eeeaf79ed5b768cd172ad0ac">on_tracker_settle</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;d)</td></tr>
-<tr class="memdesc:a023a5c57eeeaf79ed5b768cd172ad0ac"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer settled a transfer. <br /></td></tr>
-<tr class="separator:a023a5c57eeeaf79ed5b768cd172ad0ac"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:afc96eabc76c471d61627493eadb58ac8"><td class="memItemLeft" align="right" valign="top"><a id="afc96eabc76c471d61627493eadb58ac8"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#afc96eabc76c471d61627493eadb58ac8">on_delivery_settle</a> (<a class="el" href="classproton_1_1delivery.html">delivery</a> &amp;d)</td></tr>
-<tr class="memdesc:afc96eabc76c471d61627493eadb58ac8"><td class="mdescLeft">&#160;</td><td class="mdescRight">The sending peer settled a transfer. <br /></td></tr>
-<tr class="separator:afc96eabc76c471d61627493eadb58ac8"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ad3d23a7c3849dabd137610f8ee1569e3"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ad3d23a7c3849dabd137610f8ee1569e3">on_sender_drain_start</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;s)</td></tr>
-<tr class="memdesc:ad3d23a7c3849dabd137610f8ee1569e3"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - The receiving peer has requested a drain of remaining credit.  <a href="#ad3d23a7c3849dabd137610f8ee1569e3">More...</a><br /></td></tr>
-<tr class="separator:ad3d23a7c3849dabd137610f8ee1569e3"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a815e30c6d10d923d88dc1085b7b0f116"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a815e30c6d10d923d88dc1085b7b0f116">on_receiver_drain_finish</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;r)</td></tr>
-<tr class="memdesc:a815e30c6d10d923d88dc1085b7b0f116"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - The credit outstanding at the time of the call to <a class="el" href="classproton_1_1receiver.html#af7d01b5776b9d8a0f218aec331ddaeb9" title="Unsettled API - Commence a drain cycle. ">receiver::drain</a> has been consumed or returned.  <a href="#a815e30c6d10d923d88dc1085b7b0f116">More...</a><br /></td></tr>
-<tr class="separator:a815e30c6d10d923d88dc1085b7b0f116"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a9188622c33638e076d2214080129c824"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">on_container_start</a> (<a class="el" href="classproton_1_1container.html">container</a> &amp;)</td></tr>
+<tr class="memdesc:a9188622c33638e076d2214080129c824"><td class="mdescLeft">&#160;</td><td class="mdescRight">The container event loop is starting.  <a href="#a9188622c33638e076d2214080129c824">More...</a><br /></td></tr>
+<tr class="separator:a9188622c33638e076d2214080129c824"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ac6a0a8d9aad83b7e5a5b2f8a70f23c90"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">on_container_stop</a> (<a class="el" href="classproton_1_1container.html">container</a> &amp;)</td></tr>
+<tr class="memdesc:ac6a0a8d9aad83b7e5a5b2f8a70f23c90"><td class="mdescLeft">&#160;</td><td class="mdescRight">The container event loop is stopping.  <a href="#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">More...</a><br /></td></tr>
+<tr class="separator:ac6a0a8d9aad83b7e5a5b2f8a70f23c90"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a584c9daeadf4322801f58e054017fecb"><td class="memItemLeft" align="right" valign="top"><a id="a584c9daeadf4322801f58e054017fecb"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">on_message</a> (<a class="el" href="classproton_1_1delivery.html">delivery</a> &amp;, <a class="el" href="classproton_1_1message.html">message</a> &amp;)</td></tr>
+<tr class="memdesc:a584c9daeadf4322801f58e054017fecb"><td class="mdescLeft">&#160;</td><td class="mdescRight">A message is received. <br /></td></tr>
+<tr class="separator:a584c9daeadf4322801f58e054017fecb"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a86c9509ba3ce1925150c5b7a9a937c94"><td class="memItemLeft" align="right" valign="top"><a id="a86c9509ba3ce1925150c5b7a9a937c94"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">on_sendable</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:a86c9509ba3ce1925150c5b7a9a937c94"><td class="mdescLeft">&#160;</td><td class="mdescRight">A message can be sent. <br /></td></tr>
+<tr class="separator:a86c9509ba3ce1925150c5b7a9a937c94"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aa68ce0021c22cc956890c6bcc5384b84"><td class="memItemLeft" align="right" valign="top"><a id="aa68ce0021c22cc956890c6bcc5384b84"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aa68ce0021c22cc956890c6bcc5384b84">on_transport_open</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;)</td></tr>
+<tr class="memdesc:aa68ce0021c22cc956890c6bcc5384b84"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport is open. <br /></td></tr>
+<tr class="separator:aa68ce0021c22cc956890c6bcc5384b84"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a8a60c2f6628f44a9587deea8c8729f0f"><td class="memItemLeft" align="right" valign="top"><a id="a8a60c2f6628f44a9587deea8c8729f0f"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f">on_transport_close</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;)</td></tr>
+<tr class="memdesc:a8a60c2f6628f44a9587deea8c8729f0f"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport has closed. <br /></td></tr>
+<tr class="separator:a8a60c2f6628f44a9587deea8c8729f0f"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ab719e98555bab69986acf4ab1fe43665"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665">on_transport_error</a> (<a class="el" href="classproton_1_1transport.html">transport</a> &amp;)</td></tr>
+<tr class="memdesc:ab719e98555bab69986acf4ab1fe43665"><td class="mdescLeft">&#160;</td><td class="mdescRight">The underlying network transport has closed with an error condition.  <a href="#ab719e98555bab69986acf4ab1fe43665">More...</a><br /></td></tr>
+<tr class="separator:ab719e98555bab69986acf4ab1fe43665"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a41277abe0e33a3df2764b08dcc12d768"><td class="memItemLeft" align="right" valign="top"><a id="a41277abe0e33a3df2764b08dcc12d768"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">on_connection_open</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;)</td></tr>
+<tr class="memdesc:a41277abe0e33a3df2764b08dcc12d768"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the connection. <br /></td></tr>
+<tr class="separator:a41277abe0e33a3df2764b08dcc12d768"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a8368c2f41b5c1dab4aa063c1c78a6e19"><td class="memItemLeft" align="right" valign="top"><a id="a8368c2f41b5c1dab4aa063c1c78a6e19"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a8368c2f41b5c1dab4aa063c1c78a6e19">on_connection_close</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;)</td></tr>
+<tr class="memdesc:a8368c2f41b5c1dab4aa063c1c78a6e19"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the connection. <br /></td></tr>
+<tr class="separator:a8368c2f41b5c1dab4aa063c1c78a6e19"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ae93110a9bad4868663f37d15cd3139a4"><td class="memItemLeft" align="right" valign="top"><a id="ae93110a9bad4868663f37d15cd3139a4"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ae93110a9bad4868663f37d15cd3139a4">on_connection_error</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;)</td></tr>
+<tr class="memdesc:ae93110a9bad4868663f37d15cd3139a4"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the connection with an error condition. <br /></td></tr>
+<tr class="separator:ae93110a9bad4868663f37d15cd3139a4"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aad43a0028727310bcdbd8f63feb99537"><td class="memItemLeft" align="right" valign="top"><a id="aad43a0028727310bcdbd8f63feb99537"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aad43a0028727310bcdbd8f63feb99537">on_session_open</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;)</td></tr>
+<tr class="memdesc:aad43a0028727310bcdbd8f63feb99537"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the session. <br /></td></tr>
+<tr class="separator:aad43a0028727310bcdbd8f63feb99537"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aa3ff10317b9fdcbe00e500cb1e9c96ec"><td class="memItemLeft" align="right" valign="top"><a id="aa3ff10317b9fdcbe00e500cb1e9c96ec"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aa3ff10317b9fdcbe00e500cb1e9c96ec">on_session_close</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;)</td></tr>
+<tr class="memdesc:aa3ff10317b9fdcbe00e500cb1e9c96ec"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the session. <br /></td></tr>
+<tr class="separator:aa3ff10317b9fdcbe00e500cb1e9c96ec"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a63bb630e8dc357b22d6c33781c7c6a11"><td class="memItemLeft" align="right" valign="top"><a id="a63bb630e8dc357b22d6c33781c7c6a11"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a63bb630e8dc357b22d6c33781c7c6a11">on_session_error</a> (<a class="el" href="classproton_1_1session.html">session</a> &amp;)</td></tr>
+<tr class="memdesc:a63bb630e8dc357b22d6c33781c7c6a11"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the session with an error condition. <br /></td></tr>
+<tr class="separator:a63bb630e8dc357b22d6c33781c7c6a11"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a77f7e38659ee43ccb764e417ad6dd401"><td class="memItemLeft" align="right" valign="top"><a id="a77f7e38659ee43ccb764e417ad6dd401"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401">on_receiver_open</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;)</td></tr>
+<tr class="memdesc:a77f7e38659ee43ccb764e417ad6dd401"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the link. <br /></td></tr>
+<tr class="separator:a77f7e38659ee43ccb764e417ad6dd401"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a06b10fbf8524545eaf88def91d7235ef"><td class="memItemLeft" align="right" valign="top"><a id="a06b10fbf8524545eaf88def91d7235ef"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a06b10fbf8524545eaf88def91d7235ef">on_receiver_detach</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;)</td></tr>
+<tr class="memdesc:a06b10fbf8524545eaf88def91d7235ef"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer detached the link. <br /></td></tr>
+<tr class="separator:a06b10fbf8524545eaf88def91d7235ef"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ae51075d0f1d0c180bc8098370957ae28"><td class="memItemLeft" align="right" valign="top"><a id="ae51075d0f1d0c180bc8098370957ae28"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28">on_receiver_close</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;)</td></tr>
+<tr class="memdesc:ae51075d0f1d0c180bc8098370957ae28"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link. <br /></td></tr>
+<tr class="separator:ae51075d0f1d0c180bc8098370957ae28"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ac0daca9ec2dc45353a04069c6a12f3aa"><td class="memItemLeft" align="right" valign="top"><a id="ac0daca9ec2dc45353a04069c6a12f3aa"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ac0daca9ec2dc45353a04069c6a12f3aa">on_receiver_error</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;)</td></tr>
+<tr class="memdesc:ac0daca9ec2dc45353a04069c6a12f3aa"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link with an error condition. <br /></td></tr>
+<tr class="separator:ac0daca9ec2dc45353a04069c6a12f3aa"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ac655d56c64574c9eb7b10e80d32764f4"><td class="memItemLeft" align="right" valign="top"><a id="ac655d56c64574c9eb7b10e80d32764f4"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">on_sender_open</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:ac655d56c64574c9eb7b10e80d32764f4"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer opened the link. <br /></td></tr>
+<tr class="separator:ac655d56c64574c9eb7b10e80d32764f4"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ae103f0e8f35a8aebfb14b96c298ed938"><td class="memItemLeft" align="right" valign="top"><a id="ae103f0e8f35a8aebfb14b96c298ed938"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ae103f0e8f35a8aebfb14b96c298ed938">on_sender_detach</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:ae103f0e8f35a8aebfb14b96c298ed938"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer detached the link. <br /></td></tr>
+<tr class="separator:ae103f0e8f35a8aebfb14b96c298ed938"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aa604b2d3dad610ded346b0dcf3ec6f29"><td class="memItemLeft" align="right" valign="top"><a id="aa604b2d3dad610ded346b0dcf3ec6f29"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29">on_sender_close</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:aa604b2d3dad610ded346b0dcf3ec6f29"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link. <br /></td></tr>
+<tr class="separator:aa604b2d3dad610ded346b0dcf3ec6f29"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a2347cff02f9ed958ca41fcc31e58d792"><td class="memItemLeft" align="right" valign="top"><a id="a2347cff02f9ed958ca41fcc31e58d792"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a2347cff02f9ed958ca41fcc31e58d792">on_sender_error</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:a2347cff02f9ed958ca41fcc31e58d792"><td class="mdescLeft">&#160;</td><td class="mdescRight">The remote peer closed the link with an error condition. <br /></td></tr>
+<tr class="separator:a2347cff02f9ed958ca41fcc31e58d792"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a4e61812588fe6fbde253b41f7c02e993"><td class="memItemLeft" align="right" valign="top"><a id="a4e61812588fe6fbde253b41f7c02e993"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a4e61812588fe6fbde253b41f7c02e993">on_tracker_accept</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;)</td></tr>
+<tr class="memdesc:a4e61812588fe6fbde253b41f7c02e993"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer accepted a transfer. <br /></td></tr>
+<tr class="separator:a4e61812588fe6fbde253b41f7c02e993"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a116c831b8a80727a451ce20c44d781f8"><td class="memItemLeft" align="right" valign="top"><a id="a116c831b8a80727a451ce20c44d781f8"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a116c831b8a80727a451ce20c44d781f8">on_tracker_reject</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;)</td></tr>
+<tr class="memdesc:a116c831b8a80727a451ce20c44d781f8"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer rejected a transfer. <br /></td></tr>
+<tr class="separator:a116c831b8a80727a451ce20c44d781f8"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ad107964511dce62449ca730e9b0aca88"><td class="memItemLeft" align="right" valign="top"><a id="ad107964511dce62449ca730e9b0aca88"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ad107964511dce62449ca730e9b0aca88">on_tracker_release</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;)</td></tr>
+<tr class="memdesc:ad107964511dce62449ca730e9b0aca88"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer released a transfer. <br /></td></tr>
+<tr class="separator:ad107964511dce62449ca730e9b0aca88"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a36620e631024c73f5c6766abf95a8356"><td class="memItemLeft" align="right" valign="top"><a id="a36620e631024c73f5c6766abf95a8356"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a36620e631024c73f5c6766abf95a8356">on_tracker_settle</a> (<a class="el" href="classproton_1_1tracker.html">tracker</a> &amp;)</td></tr>
+<tr class="memdesc:a36620e631024c73f5c6766abf95a8356"><td class="mdescLeft">&#160;</td><td class="mdescRight">The receiving peer settled a transfer. <br /></td></tr>
+<tr class="separator:a36620e631024c73f5c6766abf95a8356"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a4f0e5cebf65a87f301ba5ef82eb8537d"><td class="memItemLeft" align="right" valign="top"><a id="a4f0e5cebf65a87f301ba5ef82eb8537d"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a4f0e5cebf65a87f301ba5ef82eb8537d">on_delivery_settle</a> (<a class="el" href="classproton_1_1delivery.html">delivery</a> &amp;)</td></tr>
+<tr class="memdesc:a4f0e5cebf65a87f301ba5ef82eb8537d"><td class="mdescLeft">&#160;</td><td class="mdescRight">The sending peer settled a transfer. <br /></td></tr>
+<tr class="separator:a4f0e5cebf65a87f301ba5ef82eb8537d"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ac07a9aab7eee64a7415f1cacc278344b"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#ac07a9aab7eee64a7415f1cacc278344b">on_sender_drain_start</a> (<a class="el" href="classproton_1_1sender.html">sender</a> &amp;)</td></tr>
+<tr class="memdesc:ac07a9aab7eee64a7415f1cacc278344b"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - The receiving peer has requested a drain of remaining credit.  <a href="#ac07a9aab7eee64a7415f1cacc278344b">More...</a><br /></td></tr>
+<tr class="separator:ac07a9aab7eee64a7415f1cacc278344b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a0c3ba013a3515fd3d0a1871c984e497e"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a0c3ba013a3515fd3d0a1871c984e497e">on_receiver_drain_finish</a> (<a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;)</td></tr>
+<tr class="memdesc:a0c3ba013a3515fd3d0a1871c984e497e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - The credit outstanding at the time of the drain request has been consumed or returned.  <a href="#a0c3ba013a3515fd3d0a1871c984e497e">More...</a><br /></td></tr>
+<tr class="separator:a0c3ba013a3515fd3d0a1871c984e497e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a29bfba2d26604e5d8d7f3183f1374481"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481">on_connection_wake</a> (<a class="el" href="classproton_1_1connection.html">connection</a> &amp;)</td></tr>
-<tr class="memdesc:a29bfba2d26604e5d8d7f3183f1374481"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - an event that can be triggered from another thread.  <a href="#a29bfba2d26604e5d8d7f3183f1374481">More...</a><br /></td></tr>
+<tr class="memdesc:a29bfba2d26604e5d8d7f3183f1374481"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - An event that can be triggered from another thread.  <a href="#a29bfba2d26604e5d8d7f3183f1374481">More...</a><br /></td></tr>
 <tr class="separator:a29bfba2d26604e5d8d7f3183f1374481"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a5e29fef3b8c5b8cf18aa7d69850ac22e"><td class="memItemLeft" align="right" valign="top"><a id="a5e29fef3b8c5b8cf18aa7d69850ac22e"></a>
-virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">on_error</a> (const <a class="el" href="classproton_1_1error__condition.html">error_condition</a> &amp;c)</td></tr>
-<tr class="memdesc:a5e29fef3b8c5b8cf18aa7d69850ac22e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Fallback error handling. <br /></td></tr>
-<tr class="separator:a5e29fef3b8c5b8cf18aa7d69850ac22e"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a042f595d1807eb1abe0195ab79357edd"><td class="memItemLeft" align="right" valign="top"><a id="a042f595d1807eb1abe0195ab79357edd"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">on_error</a> (const <a class="el" href="classproton_1_1error__condition.html">error_condition</a> &amp;)</td></tr>
+<tr class="memdesc:a042f595d1807eb1abe0195ab79357edd"><td class="mdescLeft">&#160;</td><td class="mdescRight">Fallback error handling. <br /></td></tr>
+<tr class="separator:a042f595d1807eb1abe0195ab79357edd"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A handler for Proton messaging events. </p>
@@ -228,13 +228,13 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 <li>If <code>X</code> is closed cleanly, with no error status, then <code>on_X_close</code> is called.</li>
 <li>If <code>X</code> is closed with an error, then <code>on_X_error</code> is called, followed by <code>on_X_close</code>. The error condition is also available in <code>on_X_close</code> from <code>X::error()</code>.</li>
 </ul>
-<p>By default, if you do not implement <code>on_X_error</code>, it will call <code>on_error</code>. If you do not implement <code>on_error</code> it will throw a <a class="el" href="structproton_1_1error.html">proton::error</a> exception, which may not be what you want but does help to identify forgotten error handling quickly.</p>
+<p>By default, if you do not implement <code>on_X_error</code>, it will call <code>on_error</code>. If you do not implement <code>on_error</code> it will throw a <code><a class="el" href="structproton_1_1error.html" title="The base Proton error. ">proton::error</a></code> exception, which may not be what you want but does help to identify forgotten error handling quickly.</p>
 <h4>Resource cleanup</h4>
 <p>Every <code>on_X_open</code> event is paired with an <code>on_X_close</code> event which can clean up any resources created by the open handler. In particular this is still true if an error is reported with an <code>on_X_error</code> event. The error-handling logic doesn't have to manage resource clean up. It can assume that the close event will be along to handle it. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a0">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a2">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a0">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a0">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a0">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a0">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a0">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a0">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a0">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a0">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#_a0">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a0">server_dir
 ect.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a4">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a0">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a0">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a0">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a2">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a0">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a0">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a0">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a0">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a0">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a0">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a0">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#_a0">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a0">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a4">service_bus.cpp</a>,
  <a class="el" href="simple_recv_8cpp-example.html#_a0">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a0">simple_send.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
-<a id="a4949b0c93402fae0c07492d984688a25"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a4949b0c93402fae0c07492d984688a25">&#9670;&nbsp;</a></span>on_container_start()</h2>
+<a id="a9188622c33638e076d2214080129c824"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a9188622c33638e076d2214080129c824">&#9670;&nbsp;</a></span>on_container_start()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -246,7 +246,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
           <td class="memname">virtual void on_container_start </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="classproton_1_1container.html">container</a> &amp;&#160;</td>
-          <td class="paramname"><em>c</em></td><td>)</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
@@ -258,13 +258,13 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 </div><div class="memdoc">
 
 <p>The container event loop is starting. </p>
-<p>This is the first event received after calling <a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">container::run</a> </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a5">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a2">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a2">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a2">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a2">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a8">multithreaded_client.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a5">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a4">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#a3">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#a1">server_direct.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a2">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a2">simple_send.cpp</a>.</dd>
+<p>This is the first event received after calling <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">container::run()</a></code>. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a5">client.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a1">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a8">multithreaded_client.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a5">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a4">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#a2">server.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a2">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a2">simple_send.cpp</a>.</dd>
 </dl>
 </div>
 </div>
-<a id="ab5bb8195e26c8818c4f57a734566ecfd"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ab5bb8195e26c8818c4f57a734566ecfd">&#9670;&nbsp;</a></span>on_container_stop()</h2>
+<a id="ac6a0a8d9aad83b7e5a5b2f8a70f23c90"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ac6a0a8d9aad83b7e5a5b2f8a70f23c90">&#9670;&nbsp;</a></span>on_container_stop()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -276,7 +276,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
           <td class="memname">virtual void on_container_stop </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="classproton_1_1container.html">container</a> &amp;&#160;</td>
-          <td class="paramname"><em>c</em></td><td>)</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
@@ -292,8 +292,8 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 
 </div>
 </div>
-<a id="af89551ce0e44ae3465d4b078f1c87653"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#af89551ce0e44ae3465d4b078f1c87653">&#9670;&nbsp;</a></span>on_transport_error()</h2>
+<a id="ab719e98555bab69986acf4ab1fe43665"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ab719e98555bab69986acf4ab1fe43665">&#9670;&nbsp;</a></span>on_transport_error()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -305,7 +305,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
           <td class="memname">virtual void on_transport_error </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="classproton_1_1transport.html">transport</a> &amp;&#160;</td>
-          <td class="paramname"><em>t</em></td><td>)</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
@@ -320,8 +320,8 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 
 </div>
 </div>
-<a id="ad3d23a7c3849dabd137610f8ee1569e3"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#ad3d23a7c3849dabd137610f8ee1569e3">&#9670;&nbsp;</a></span>on_sender_drain_start()</h2>
+<a id="ac07a9aab7eee64a7415f1cacc278344b"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#ac07a9aab7eee64a7415f1cacc278344b">&#9670;&nbsp;</a></span>on_sender_drain_start()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -333,7 +333,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
           <td class="memname">virtual void on_sender_drain_start </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="classproton_1_1sender.html">sender</a> &amp;&#160;</td>
-          <td class="paramname"><em>s</em></td><td>)</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
@@ -348,8 +348,8 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 
 </div>
 </div>
-<a id="a815e30c6d10d923d88dc1085b7b0f116"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a815e30c6d10d923d88dc1085b7b0f116">&#9670;&nbsp;</a></span>on_receiver_drain_finish()</h2>
+<a id="a0c3ba013a3515fd3d0a1871c984e497e"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a0c3ba013a3515fd3d0a1871c984e497e">&#9670;&nbsp;</a></span>on_receiver_drain_finish()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -361,7 +361,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
           <td class="memname">virtual void on_receiver_drain_finish </td>
           <td>(</td>
           <td class="paramtype"><a class="el" href="classproton_1_1receiver.html">receiver</a> &amp;&#160;</td>
-          <td class="paramname"><em>r</em></td><td>)</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
@@ -372,7 +372,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 </table>
 </div><div class="memdoc">
 
-<p><b>Unsettled API</b> - The credit outstanding at the time of the call to <a class="el" href="classproton_1_1receiver.html#af7d01b5776b9d8a0f218aec331ddaeb9" title="Unsettled API - Commence a drain cycle. ">receiver::drain</a> has been consumed or returned. </p>
+<p><b>Unsettled API</b> - The credit outstanding at the time of the drain request has been consumed or returned. </p>
 
 </div>
 </div>
@@ -400,11 +400,10 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 </table>
 </div><div class="memdoc">
 
-<p><b>Unsettled API</b> - an event that can be triggered from another thread. </p>
-<p><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - an event that can be triggered from another thread. ">on_connection_wake()</a> can be triggered by any thread calling <a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">connection::wake()</a> It is used to notify the application's <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> instance that something needs attention.</p>
-<p>The application handler and the triggering thread must use some form of thread-safe state or communication to tell the handler what it needs to do.</p>
-<dl class="section note"><dt>Note</dt><dd>spurious calls to <a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - an event that can be triggered from another thread. ">on_connection_wake()</a> can occur without any application call to <a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">connection::wake()</a></dd></dl>
-<dl class="section see"><dt>See also</dt><dd><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">work_queue</a> provides an easier way execute code safely in the handler thread. </dd></dl>
+<p><b>Unsettled API</b> - An event that can be triggered from another thread. </p>
+<p>This event is triggered by a call to <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">connection::wake()</a></code>. It is used to notify the application that something needs attention.</p>
+<p><b>Thread-safety</b> - The application handler and the triggering thread must use some form of thread-safe state or communication to tell the handler what it needs to do. See <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> for an easier way to execute code safely in the handler thread.</p>
+<dl class="section note"><dt>Note</dt><dd>Spurious calls to <code><a class="el" href="classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481" title="Unsettled API - An event that can be triggered from another thread. ">on_connection_wake()</a></code> can occur without any application call to <code><a class="el" href="classproton_1_1connection.html#a473371542eaeba6f67660582fe6a6074" title="Unsettled API - Trigger an event from another thread. ">connection::wake()</a></code>. </dd></dl>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.js
index 8ec14b1..f45360c 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1messaging__handler.js
@@ -2,34 +2,34 @@ var classproton_1_1messaging__handler =
 [
     [ "messaging_handler", "classproton_1_1messaging__handler.html#a6a8e214436bb8eda1d60a13fb4bc1cc2", null ],
     [ "~messaging_handler", "classproton_1_1messaging__handler.html#a68692afef03d64a8ae1af0923e1fa13e", null ],
-    [ "on_container_start", "classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25", null ],
-    [ "on_container_stop", "classproton_1_1messaging__handler.html#ab5bb8195e26c8818c4f57a734566ecfd", null ],
-    [ "on_message", "classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46", null ],
-    [ "on_sendable", "classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7", null ],
-    [ "on_transport_open", "classproton_1_1messaging__handler.html#a0c141065eda9a26916ccc63ccea5d3b7", null ],
-    [ "on_transport_close", "classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f", null ],
-    [ "on_transport_error", "classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653", null ],
-    [ "on_connection_open", "classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968", null ],
-    [ "on_connection_close", "classproton_1_1messaging__handler.html#a804f0ea9c2754f143624b4078a61f650", null ],
-    [ "on_connection_error", "classproton_1_1messaging__handler.html#aafa83dc2f8f477ba1f76e86dc69cd1e9", null ],
-    [ "on_session_open", "classproton_1_1messaging__handler.html#adddbfd9b7fc7719490bdc21331c42302", null ],
-    [ "on_session_close", "classproton_1_1messaging__handler.html#a54fe4fc5394418f8606f9263f13d2e98", null ],
-    [ "on_session_error", "classproton_1_1messaging__handler.html#aca924d2f68649df7945719be3d29a597", null ],
-    [ "on_receiver_open", "classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd", null ],
-    [ "on_receiver_detach", "classproton_1_1messaging__handler.html#a93ab65773954cf12eb7f76a26aa44cfe", null ],
-    [ "on_receiver_close", "classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907", null ],
-    [ "on_receiver_error", "classproton_1_1messaging__handler.html#a0c281aee5483822bdf4b428834bd7f28", null ],
-    [ "on_sender_open", "classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661", null ],
-    [ "on_sender_detach", "classproton_1_1messaging__handler.html#a731e7cdbda64b15f069efd560b66ada1", null ],
-    [ "on_sender_close", "classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84", null ],
-    [ "on_sender_error", "classproton_1_1messaging__handler.html#a2d9d98eee878f1e734457ba01e21228a", null ],
-    [ "on_tracker_accept", "classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad", null ],
-    [ "on_tracker_reject", "classproton_1_1messaging__handler.html#a0740e8c9ed9d0c304d2adced09802893", null ],
-    [ "on_tracker_release", "classproton_1_1messaging__handler.html#acfde5590c6e826ef9e2c33a28edefe19", null ],
-    [ "on_tracker_settle", "classproton_1_1messaging__handler.html#a023a5c57eeeaf79ed5b768cd172ad0ac", null ],
-    [ "on_delivery_settle", "classproton_1_1messaging__handler.html#afc96eabc76c471d61627493eadb58ac8", null ],
-    [ "on_sender_drain_start", "classproton_1_1messaging__handler.html#ad3d23a7c3849dabd137610f8ee1569e3", null ],
-    [ "on_receiver_drain_finish", "classproton_1_1messaging__handler.html#a815e30c6d10d923d88dc1085b7b0f116", null ],
+    [ "on_container_start", "classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824", null ],
+    [ "on_container_stop", "classproton_1_1messaging__handler.html#ac6a0a8d9aad83b7e5a5b2f8a70f23c90", null ],
+    [ "on_message", "classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb", null ],
+    [ "on_sendable", "classproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94", null ],
+    [ "on_transport_open", "classproton_1_1messaging__handler.html#aa68ce0021c22cc956890c6bcc5384b84", null ],
+    [ "on_transport_close", "classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f", null ],
+    [ "on_transport_error", "classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665", null ],
+    [ "on_connection_open", "classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768", null ],
+    [ "on_connection_close", "classproton_1_1messaging__handler.html#a8368c2f41b5c1dab4aa063c1c78a6e19", null ],
+    [ "on_connection_error", "classproton_1_1messaging__handler.html#ae93110a9bad4868663f37d15cd3139a4", null ],
+    [ "on_session_open", "classproton_1_1messaging__handler.html#aad43a0028727310bcdbd8f63feb99537", null ],
+    [ "on_session_close", "classproton_1_1messaging__handler.html#aa3ff10317b9fdcbe00e500cb1e9c96ec", null ],
+    [ "on_session_error", "classproton_1_1messaging__handler.html#a63bb630e8dc357b22d6c33781c7c6a11", null ],
+    [ "on_receiver_open", "classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401", null ],
+    [ "on_receiver_detach", "classproton_1_1messaging__handler.html#a06b10fbf8524545eaf88def91d7235ef", null ],
+    [ "on_receiver_close", "classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28", null ],
+    [ "on_receiver_error", "classproton_1_1messaging__handler.html#ac0daca9ec2dc45353a04069c6a12f3aa", null ],
+    [ "on_sender_open", "classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4", null ],
+    [ "on_sender_detach", "classproton_1_1messaging__handler.html#ae103f0e8f35a8aebfb14b96c298ed938", null ],
+    [ "on_sender_close", "classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29", null ],
+    [ "on_sender_error", "classproton_1_1messaging__handler.html#a2347cff02f9ed958ca41fcc31e58d792", null ],
+    [ "on_tracker_accept", "classproton_1_1messaging__handler.html#a4e61812588fe6fbde253b41f7c02e993", null ],
+    [ "on_tracker_reject", "classproton_1_1messaging__handler.html#a116c831b8a80727a451ce20c44d781f8", null ],
+    [ "on_tracker_release", "classproton_1_1messaging__handler.html#ad107964511dce62449ca730e9b0aca88", null ],
+    [ "on_tracker_settle", "classproton_1_1messaging__handler.html#a36620e631024c73f5c6766abf95a8356", null ],
+    [ "on_delivery_settle", "classproton_1_1messaging__handler.html#a4f0e5cebf65a87f301ba5ef82eb8537d", null ],
+    [ "on_sender_drain_start", "classproton_1_1messaging__handler.html#ac07a9aab7eee64a7415f1cacc278344b", null ],
+    [ "on_receiver_drain_finish", "classproton_1_1messaging__handler.html#a0c3ba013a3515fd3d0a1871c984e497e", null ],
     [ "on_connection_wake", "classproton_1_1messaging__handler.html#a29bfba2d26604e5d8d7f3183f1374481", null ],
-    [ "on_error", "classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e", null ]
+    [ "on_error", "classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null-members.html
new file mode 100755
index 0000000..da5fdbe
--- /dev/null
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null-members.html
@@ -0,0 +1,112 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
+<html xmlns="http://www.w3.org/1999/xhtml">
+<head>
+<meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
+<meta http-equiv="X-UA-Compatible" content="IE=9"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
+<title>Qpid Proton C++ API: Member List</title>
+<link href="tabs.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="jquery.js"></script>
+<script type="text/javascript" src="dynsections.js"></script>
+<link href="navtree.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="resize.js"></script>
+<script type="text/javascript" src="navtreedata.js"></script>
+<script type="text/javascript" src="navtree.js"></script>
+<script type="text/javascript">
+  $(document).ready(initResizable);
+</script>
+<link href="search/search.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="search/searchdata.js"></script>
+<script type="text/javascript" src="search/search.js"></script>
+<script type="text/javascript">
+  $(document).ready(function() { init_search(); });
+</script>
+<link href="doxygen.css" rel="stylesheet" type="text/css" />
+</head>
+<body>
+<div id="top"><!-- do not remove this div, it is closed by doxygen! -->
+<div id="titlearea">
+<table cellspacing="0" cellpadding="0">
+ <tbody>
+ <tr style="height: 56px;">
+  <td id="projectalign" style="padding-left: 0.5em;">
+   <div id="projectname">Qpid Proton C++ API
+   &#160;<span id="projectnumber">master</span>
+   </div>
+  </td>
+   <td>        <div id="MSearchBox" class="MSearchBoxInactive">
+        <span class="left">
+          <img id="MSearchSelect" src="search/mag_sel.png"
+               onmouseover="return searchBox.OnSearchSelectShow()"
+               onmouseout="return searchBox.OnSearchSelectHide()"
+               alt=""/>
+          <input type="text" id="MSearchField" value="Search" accesskey="S"
+               onfocus="searchBox.OnSearchFieldFocus(true)" 
+               onblur="searchBox.OnSearchFieldFocus(false)" 
+               onkeyup="searchBox.OnSearchFieldChange(event)"/>
+          </span><span class="right">
+            <a id="MSearchClose" href="javascript:searchBox.CloseResultsWindow()"><img id="MSearchCloseImg" border="0" src="search/close.png" alt=""/></a>
+          </span>
+        </div>
+</td>
+ </tr>
+ </tbody>
+</table>
+</div>
+<!-- end header part -->
+<!-- Generated by Doxygen 1.8.13 -->
+<script type="text/javascript">
+var searchBox = new SearchBox("searchBox", "search",false,'Search');
+</script>
+</div><!-- top -->
+<div id="side-nav" class="ui-resizable side-nav-resizable">
+  <div id="nav-tree">
+    <div id="nav-tree-contents">
+      <div id="nav-sync" class="sync"></div>
+    </div>
+  </div>
+  <div id="splitbar" style="-moz-user-select:none;" 
+       class="ui-resizable-handle">
+  </div>
+</div>
+<script type="text/javascript">
+$(document).ready(function(){initNavTree('classproton_1_1null.html','');});
+</script>
+<div id="doc-content">
+<!-- window showing the filter options -->
+<div id="MSearchSelectWindow"
+     onmouseover="return searchBox.OnSearchSelectShow()"
+     onmouseout="return searchBox.OnSearchSelectHide()"
+     onkeydown="return searchBox.OnSearchSelectKey(event)">
+</div>
+
+<!-- iframe showing the search results (closed by default) -->
+<div id="MSearchResultsWindow">
+<iframe src="javascript:void(0)" frameborder="0" 
+        name="MSearchResults" id="MSearchResults">
+</iframe>
+</div>
+
+<div class="header">
+  <div class="headertitle">
+<div class="title">null Member List</div>  </div>
+</div><!--header-->
+<div class="contents">
+
+<p>This is the complete list of members for <a class="el" href="classproton_1_1null.html">null</a>, including all inherited members.</p>
+<table class="directory">
+  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>null</b>() (defined in <a class="el" href="classproton_1_1null.html">null</a>)</td><td class="entry"><a class="el" href="classproton_1_1null.html">null</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1null.html#ac6f7583eff281f509c7351b850ad131b">null</a>(decltype(nullptr))</td><td class="entry"><a class="el" href="classproton_1_1null.html">null</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+</table></div><!-- contents -->
+</div><!-- doc-content -->
+<!-- start footer part -->
+<div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
+  <ul>
+    <li class="footer">Generated by
+    <a href="http://www.doxygen.org/index.html">
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
+  </ul>
+</div>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.html
new file mode 100755
index 0000000..171ada9
--- /dev/null
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.html
@@ -0,0 +1,130 @@
+<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
+<html xmlns="http://www.w3.org/1999/xhtml">
+<head>
+<meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
+<meta http-equiv="X-UA-Compatible" content="IE=9"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
+<title>Qpid Proton C++ API: null</title>
+<link href="tabs.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="jquery.js"></script>
+<script type="text/javascript" src="dynsections.js"></script>
+<link href="navtree.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="resize.js"></script>
+<script type="text/javascript" src="navtreedata.js"></script>
+<script type="text/javascript" src="navtree.js"></script>
+<script type="text/javascript">
+  $(document).ready(initResizable);
+</script>
+<link href="search/search.css" rel="stylesheet" type="text/css"/>
+<script type="text/javascript" src="search/searchdata.js"></script>
+<script type="text/javascript" src="search/search.js"></script>
+<script type="text/javascript">
+  $(document).ready(function() { init_search(); });
+</script>
+<link href="doxygen.css" rel="stylesheet" type="text/css" />
+</head>
+<body>
+<div id="top"><!-- do not remove this div, it is closed by doxygen! -->
+<div id="titlearea">
+<table cellspacing="0" cellpadding="0">
+ <tbody>
+ <tr style="height: 56px;">
+  <td id="projectalign" style="padding-left: 0.5em;">
+   <div id="projectname">Qpid Proton C++ API
+   &#160;<span id="projectnumber">master</span>
+   </div>
+  </td>
+   <td>        <div id="MSearchBox" class="MSearchBoxInactive">
+        <span class="left">
+          <img id="MSearchSelect" src="search/mag_sel.png"
+               onmouseover="return searchBox.OnSearchSelectShow()"
+               onmouseout="return searchBox.OnSearchSelectHide()"
+               alt=""/>
+          <input type="text" id="MSearchField" value="Search" accesskey="S"
+               onfocus="searchBox.OnSearchFieldFocus(true)" 
+               onblur="searchBox.OnSearchFieldFocus(false)" 
+               onkeyup="searchBox.OnSearchFieldChange(event)"/>
+          </span><span class="right">
+            <a id="MSearchClose" href="javascript:searchBox.CloseResultsWindow()"><img id="MSearchCloseImg" border="0" src="search/close.png" alt=""/></a>
+          </span>
+        </div>
+</td>
+ </tr>
+ </tbody>
+</table>
+</div>
+<!-- end header part -->
+<!-- Generated by Doxygen 1.8.13 -->
+<script type="text/javascript">
+var searchBox = new SearchBox("searchBox", "search",false,'Search');
+</script>
+</div><!-- top -->
+<div id="side-nav" class="ui-resizable side-nav-resizable">
+  <div id="nav-tree">
+    <div id="nav-tree-contents">
+      <div id="nav-sync" class="sync"></div>
+    </div>
+  </div>
+  <div id="splitbar" style="-moz-user-select:none;" 
+       class="ui-resizable-handle">
+  </div>
+</div>
+<script type="text/javascript">
+$(document).ready(function(){initNavTree('classproton_1_1null.html','');});
+</script>
+<div id="doc-content">
+<!-- window showing the filter options -->
+<div id="MSearchSelectWindow"
+     onmouseover="return searchBox.OnSearchSelectShow()"
+     onmouseout="return searchBox.OnSearchSelectHide()"
+     onkeydown="return searchBox.OnSearchSelectKey(event)">
+</div>
+
+<!-- iframe showing the search results (closed by default) -->
+<div id="MSearchResultsWindow">
+<iframe src="javascript:void(0)" frameborder="0" 
+        name="MSearchResults" id="MSearchResults">
+</iframe>
+</div>
+
+<div class="header">
+  <div class="summary">
+<a href="#pub-methods">Public Member Functions</a> &#124;
+<a href="classproton_1_1null-members.html">List of all members</a>  </div>
+  <div class="headertitle">
+<div class="title">null</div>  </div>
+</div><!--header-->
+<div class="contents">
+
+<p>The type of the AMQP null value.  
+ <a href="classproton_1_1null.html#details">More...</a></p>
+
+<p><code>#include &lt;<a class="el" href="null_8hpp_source.html">null.hpp</a>&gt;</code></p>
+<table class="memberdecls">
+<tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
+Public Member Functions</h2></td></tr>
+<tr class="memitem:ac6f7583eff281f509c7351b850ad131b"><td class="memItemLeft" align="right" valign="top"><a id="ac6f7583eff281f509c7351b850ad131b"></a>
+&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1null.html#ac6f7583eff281f509c7351b850ad131b">null</a> (decltype(nullptr))</td></tr>
+<tr class="memdesc:ac6f7583eff281f509c7351b850ad131b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Constructed from nullptr literal. <br /></td></tr>
+<tr class="separator:ac6f7583eff281f509c7351b850ad131b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+</table>
+<a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
+<div class="textblock"><p>The type of the AMQP null value. </p>
+<dl class="section see"><dt>See also</dt><dd><a class="el" href="types_page.html">AMQP and C++ types</a> </dd></dl>
+</div><hr/>The documentation for this class was generated from the following file:<ul>
+<li>proton/<a class="el" href="null_8hpp_source.html">null.hpp</a></li>
+</ul>
+</div><!-- contents -->
+</div><!-- doc-content -->
+<!-- start footer part -->
+<div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
+  <ul>
+    <li class="navelem"><a class="el" href="namespaceproton.html">proton</a></li><li class="navelem"><a class="el" href="classproton_1_1null.html">null</a></li>
+    <li class="footer">Generated by
+    <a href="http://www.doxygen.org/index.html">
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
+  </ul>
+</div>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.js
new file mode 100755
index 0000000..5e157c0
--- /dev/null
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1null.js
@@ -0,0 +1,5 @@
+var classproton_1_1null =
+[
+    [ "null", "classproton_1_1null.html#acbefd91cf0ce9643b1ea0e735653d195", null ],
+    [ "null", "classproton_1_1null.html#ac6f7583eff281f509c7351b850ad131b", null ]
+];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver.html
index ed2e3c0..1f2b7f3 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver.html
@@ -193,7 +193,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A channel for receiving messages. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a15">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a4">client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a17">multithreaded_client_flow_control.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a9">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#_a1">simple_recv.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a13">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a4">client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a17">multithreaded_client_flow_control.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a9">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#_a1">simple_recv.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a9e8555112049fc2b4945120b3c45f8ab"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a9e8555112049fc2b4945120b3c45f8ab">&#9670;&nbsp;</a></span>open() <span class="overload">[1/2]</span></h2>
@@ -212,7 +212,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 
 <p>Open the receiver. </p>
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a17">broker.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a15">broker.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -306,7 +306,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
 
 <p>Implements <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>.</p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a14">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a10">helloworld_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a20">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a12">helloworld.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a23">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options-members.html
index 54f870e..2ac286f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options-members.html
@@ -101,13 +101,14 @@ $(document).ready(function(){initNavTree('classproton_1_1receiver__options.html'
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a714a6a7dd1ea90c6046fe0460d2ce4f0">credit_window</a>(int count)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a582bced77754ed8a85f9597e2e457079">delivery_mode</a>(delivery_mode)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a84f38ac0f31f74011c9dc342e44a53df">handler</a>(class messaging_handler &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a815be8018205013b8ff011d4b62b7324">operator=</a>(const receiver_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a09be031fe2c8df29e3f0f1b0f1c904c3">receiver_options</a>(const receiver_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7e2689fd52f88f551d11face38a4157b">source</a>(source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7823f6c72dc78481be578de1658b99eb">target</a>(target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7bbed67f2faac1cd6a5c490dac90bda3">update</a>(const receiver_options &amp;other)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>~receiver_options</b>() (defined in <a class="el" href="classproton_1_1receiver__options.html">receiver_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a038ed50e63983958b13e42d49d270b88">name</a>(const std::string &amp;name)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a815be8018205013b8ff011d4b62b7324">operator=</a>(const receiver_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a09be031fe2c8df29e3f0f1b0f1c904c3">receiver_options</a>(const receiver_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7e2689fd52f88f551d11face38a4157b">source</a>(source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7823f6c72dc78481be578de1658b99eb">target</a>(target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1receiver__options.html#a7bbed67f2faac1cd6a5c490dac90bda3">update</a>(const receiver_options &amp;other)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~receiver_options</b>() (defined in <a class="el" href="classproton_1_1receiver__options.html">receiver_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->


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


[09/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.html b/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.html
index 202be0f..0706d8a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.html
@@ -121,7 +121,7 @@ Files</h2></td></tr>
 <tr class="memdesc:decimal_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">AMQP decimal types. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:default__container_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="default__container_8hpp.html">default_container.hpp</a> <a href="default__container_8hpp_source.html">[code]</a></td></tr>
-<tr class="memdesc:default__container_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code>. <br /></td></tr>
+<tr class="memdesc:default__container_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use the API in <code><a class="el" href="container_8hpp.html" title="A top-level container of connections, sessions, and links. ">container.hpp</a></code>. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:delivery_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="delivery_8hpp.html">delivery.hpp</a> <a href="delivery_8hpp_source.html">[code]</a></td></tr>
 <tr class="memdesc:delivery_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">A received message. <br /></td></tr>
@@ -142,7 +142,7 @@ Files</h2></td></tr>
 <tr class="memdesc:error__condition_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">Describes an endpoint error state. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:function_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="function_8hpp.html">function.hpp</a> <a href="function_8hpp_source.html">[code]</a></td></tr>
-<tr class="memdesc:function_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1work.html" title="Unsettled API - A work item for a work queue. ">proton::work</a></code>. <br /></td></tr>
+<tr class="memdesc:function_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use the API in <code><a class="el" href="work__queue_8hpp.html" title="Unsettled API - A context for thread-safe execution of work. ">work_queue.hpp</a></code>. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:fwd_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="fwd_8hpp.html">fwd.hpp</a> <a href="fwd_8hpp_source.html">[code]</a></td></tr>
 <tr class="memdesc:fwd_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">Forward declarations. <br /></td></tr>
@@ -171,6 +171,9 @@ Files</h2></td></tr>
 <tr class="memitem:namespaces_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="namespaces_8hpp.html">namespaces.hpp</a> <a href="namespaces_8hpp_source.html">[code]</a></td></tr>
 <tr class="memdesc:namespaces_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">Namespace declarations. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:null_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="null_8hpp.html">null.hpp</a> <a href="null_8hpp_source.html">[code]</a></td></tr>
+<tr class="memdesc:null_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">The type of the AMQP null value. <br /></td></tr>
+<tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:receiver_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="receiver_8hpp.html">receiver.hpp</a> <a href="receiver_8hpp_source.html">[code]</a></td></tr>
 <tr class="memdesc:receiver_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">A channel for receiving messages. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
@@ -226,7 +229,7 @@ Files</h2></td></tr>
 <tr class="memdesc:terminus_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">One end of a link, either a source or a target. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:thread__safe_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="thread__safe_8hpp.html">thread_safe.hpp</a> <a href="thread__safe_8hpp_source.html">[code]</a></td></tr>
-<tr class="memdesc:thread__safe_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Container method return values are safe to use only inside handlers. <br /></td></tr>
+<tr class="memdesc:thread__safe_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - No longer used. <br /></td></tr>
 <tr class="separator:"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:timestamp_8hpp"><td class="memItemLeft" align="right" valign="top">file &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="timestamp_8hpp.html">timestamp.hpp</a> <a href="timestamp_8hpp_source.html">[code]</a></td></tr>
 <tr class="memdesc:timestamp_8hpp"><td class="mdescLeft">&#160;</td><td class="mdescRight">A 64-bit timestamp in milliseconds since the Unix epoch. <br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.js b/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.js
index dd2d371..1b5138f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/dir_25143d27009f52d175c1d192441a738a.js
@@ -59,6 +59,7 @@ var dir_25143d27009f52d175c1d192441a738a =
       [ "messaging_handler", "classproton_1_1messaging__handler.html", "classproton_1_1messaging__handler" ]
     ] ],
     [ "namespaces.hpp", "namespaces_8hpp.html", null ],
+    [ "null.hpp", "null_8hpp.html", "null_8hpp" ],
     [ "receiver.hpp", "receiver_8hpp.html", [
       [ "receiver", "classproton_1_1receiver.html", "classproton_1_1receiver" ]
     ] ],
@@ -132,5 +133,7 @@ var dir_25143d27009f52d175c1d192441a738a =
     ] ],
     [ "uuid.hpp", "uuid_8hpp.html", "uuid_8hpp" ],
     [ "value.hpp", "value_8hpp.html", "value_8hpp" ],
-    [ "work_queue.hpp", "work__queue_8hpp.html", "work__queue_8hpp" ]
+    [ "work_queue.hpp", "work__queue_8hpp.html", [
+      [ "work_queue", "classproton_1_1work__queue.html", "classproton_1_1work__queue" ]
+    ] ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/direct_recv_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/direct_recv_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/direct_recv_8cpp-example.html
index 30c805a..a9654d1 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/direct_recv_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/direct_recv_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('direct_recv_8cpp-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>Accepts an incoming connection and then receives like <code>simple_recv</code>. You can connect directly to <code>direct_recv</code> <em>without</em> a broker using <a class="el" href="simple_send_8cpp-example.html">simple_send.cpp</a>. Make sure to stop the broker first or use a different port for <code>direct_recv</code>.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message__id_8hpp.html">proton/message_id.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="link_8hpp
 .html">proton/link.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="value_8hpp.html">proton/value.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>direct_recv : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    std::string url;</div><div class="line">    <a na
 me="_a1"></a><a class="code" href="classproton_1_1listener.html">proton::listener</a> listener;</div><div class="line">    <span class="keywordtype">int</span> expected;</div><div class="line">    <span class="keywordtype">int</span> received;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    direct_recv(<span class="keyword">const</span> std::string &amp;s, <span class="keywordtype">int</span> c) : url(s), expected(c), received(0) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a2"></a><a class="code" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a>(<a name="_a3"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        listener = c.<a name="a4"></a><a class="code" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>
 (url);</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;direct_recv listening on &quot;</span> &lt;&lt; url &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a5"></a><a class="code" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a>(<a name="_a6"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a name="_a7"></a><a class="code" href="classproton_1_1message.html">proton::message</a> &amp;msg) OVERRIDE {</div><div class="line">        <span class="keywordflow">if</span> (proton::coerce&lt;int&gt;(msg.<a name="a8"></a><a class="code" href="classproton_1_1message.html#a84811758e758988a802673edca6b77cb">id</a>()) &lt; received) {</div><div class="line">            <span class="keywordflow">return</span>; <span class="comment">// Ignore duplicate</span></div><div class="line">    
     }</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (expected == 0 || received &lt; expected) {</div><div class="line">            std::cout &lt;&lt; msg.<a name="a9"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">            received++;</div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (received == expected) {</div><div class="line">            d.<a name="a10"></a><a class="code" href="classproton_1_1delivery.html#aeb4319de46c92afec4ebbb3116d67c39">receiver</a>().<a name="a11"></a><a class="code" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            d.<a name="a12"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a13"></a><a class="code" href="cl
 assproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            listener.<a name="a14"></a><a class="code" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string address(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div class="line">    <span class="keywordtype">int</span> message_count = 100;</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;listen and rec
 eive on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line">    opts.add_value(message_count, <span class="charliteral">&#39;m&#39;</span>, <span class="stringliteral">&quot;messages&quot;</span>, <span class="stringliteral">&quot;receive COUNT messages&quot;</span>, <span class="stringliteral">&quot;COUNT&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        direct_recv recv(address, message_count);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(recv).<a name="a15"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span
  class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message__id_8hpp.html">proton/message_id.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="link_8hpp
 .html">proton/link.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listen__handler_8hpp.html">proton/listen_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="value_8hpp.html">proton/value.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>direct_recv : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_
 handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="keyword">class </span>listener_ready_handler : <span class="keyword">public</span> <a name="_a1"></a><a class="code" href="classproton_1_1listen__handler.html">proton::listen_handler</a> {</div><div class="line">        <span class="keywordtype">void</span> on_open(<a name="_a2"></a><a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp; l) OVERRIDE {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;listening on &quot;</span> &lt;&lt; l.<a name="a3"></a><a class="code" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">port</a>() &lt;&lt; std::endl;</div><div class="line">        }</div><div class="line">    };</div><div class="line"></div><div class="line">    std::string url;</div><div class="line">    <a class="code" href="classproton_1_1listener.html">proton::listener</a> listener;</di
 v><div class="line">    listener_ready_handler listen_handler;</div><div class="line">    <span class="keywordtype">int</span> expected;</div><div class="line">    <span class="keywordtype">int</span> received;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    direct_recv(<span class="keyword">const</span> std::string &amp;s, <span class="keywordtype">int</span> c) : url(s), expected(c), received(0) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_container_start(<a name="_a4"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        listener = c.<a name="a5"></a><a class="code" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>(url, listen_handler);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_messag
 e(<a name="_a6"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a name="_a7"></a><a class="code" href="classproton_1_1message.html">proton::message</a> &amp;msg) OVERRIDE {</div><div class="line">        <span class="keywordflow">if</span> (proton::coerce&lt;int&gt;(msg.<a name="a8"></a><a class="code" href="classproton_1_1message.html#a84811758e758988a802673edca6b77cb">id</a>()) &lt; received) {</div><div class="line">            <span class="keywordflow">return</span>; <span class="comment">// Ignore duplicate</span></div><div class="line">        }</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (expected == 0 || received &lt; expected) {</div><div class="line">            std::cout &lt;&lt; msg.<a name="a9"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">            received++;</div><div class="line">     
    }</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (received == expected) {</div><div class="line">            d.<a name="a10"></a><a class="code" href="classproton_1_1delivery.html#aeb4319de46c92afec4ebbb3116d67c39">receiver</a>().<a name="a11"></a><a class="code" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            d.<a name="a12"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a13"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            listener.<a name="a14"></a><a class="code" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span
 > main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string address(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div class="line">    <span class="keywordtype">int</span> message_count = 100;</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;listen and receive on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line">    opts.add_value(message_count, <span class="charliteral">&#39;m&#39;</span>, <span class="stringliteral">&quot;messages&quot;</span>, <span class="stringliteral">&quot;receive COUNT messages&quot;</span>, <span class="stringliteral">&quot;COUNT&quot;</span>);</div><div class="line"></div><div class="l
 ine">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        direct_recv recv(address, message_count);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(recv).<a name="a15"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    
 }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/direct_send_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/direct_send_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/direct_send_8cpp-example.html
index 0351ec9..e98651e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/direct_send_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/direct_send_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('direct_send_8cpp-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>Accepts an incoming connection and then sends like <code>simple_send</code>. You can connect directly to <code>direct_send</code> <em>without</em> a broker using <a class="el" href="simple_recv_8cpp-example.html">simple_recv.cpp</a>. Make sure to stop the broker first or use a different port for <code>direct_send</code>.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message__id_8hpp.html">proton/message_id.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="value_8hp
 p.html">proton/value.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="types_8hpp.html">proton/types.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>simple_send : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    std::string url;</div><div class="line">    <a na
 me="_a1"></a><a class="code" href="classproton_1_1listener.html">proton::listener</a> listener;</div><div class="line">    <span class="keywordtype">int</span> sent;</div><div class="line">    <span class="keywordtype">int</span> confirmed;</div><div class="line">    <span class="keywordtype">int</span> total;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    simple_send(<span class="keyword">const</span> std::string &amp;s, <span class="keywordtype">int</span> c) : url(s), sent(0), confirmed(0), total(c) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a2"></a><a class="code" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a>(<a name="_a3"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        listener = c.<a name="a4"></a><a class="code" href="
 classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>(url);</div><div class="line">        std::cout &lt;&lt; <span class="stringliteral">&quot;direct_send listening on &quot;</span> &lt;&lt; url &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a5"></a><a class="code" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a>(<a name="_a6"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE {</div><div class="line">        <span class="keywordflow">while</span> (sender.<a name="a7"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>() &amp;&amp; sent &lt; total) {</div><div class="line">            <a name="_a8"></a><a class="code" href="classproton_1_1message.html">proton::message</a> msg;</div><div class="line">            std::map&lt;std::
 string, int&gt; m;</div><div class="line">            m[<span class="stringliteral">&quot;sequence&quot;</span>] = sent + 1;</div><div class="line"></div><div class="line">            msg.<a name="a9"></a><a class="code" href="classproton_1_1message.html#a84811758e758988a802673edca6b77cb">id</a>(sent + 1);</div><div class="line">            msg.<a name="a10"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>(m);</div><div class="line"></div><div class="line">            sender.<a name="a11"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(msg);</div><div class="line">            sent++;</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a12"></a><a class="code" href="classproton_1_1messaging__handler.html#a003afbb57c00ce404a863152db7867ad">on_tracker_accept</a>(<a name="_a13"></a><a
  class="code" href="classproton_1_1tracker.html">proton::tracker</a> &amp;t) OVERRIDE {</div><div class="line">        confirmed++;</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (confirmed == total) {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;all messages confirmed&quot;</span> &lt;&lt; std::endl;</div><div class="line">            t.<a name="a14"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a15"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            listener.<a name="a16"></a><a class="code" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a17"></a><
 a class="code" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f">on_transport_close</a>(<a name="_a18"></a><a class="code" href="classproton_1_1transport.html">proton::transport</a> &amp;) OVERRIDE {</div><div class="line">        sent = confirmed;</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string address(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div class="line">    <span class="keywordtype">int</span> message_count = 100;</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;liste
 n and send on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line">    opts.add_value(message_count, <span class="charliteral">&#39;m&#39;</span>, <span class="stringliteral">&quot;messages&quot;</span>, <span class="stringliteral">&quot;send COUNT messages&quot;</span>, <span class="stringliteral">&quot;COUNT&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        simple_send send(address, message_count);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(send).<a name="a19"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">cons
 t</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;options.hpp&qu
 ot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listen__handler_8hpp.html">proton/listen_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8hpp.html">proton/listener.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message__id_8hpp.html">proton/message_id.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__hand
 ler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="value_8hpp.html">proton/value.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="types_8hpp.html">proton/types.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;map&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>simple_send : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_
 handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <span class="keyword">class </span>listener_ready_handler : <span class="keyword">public</span> <a name="_a1"></a><a class="code" href="classproton_1_1listen__handler.html">proton::listen_handler</a> {</div><div class="line">        <span class="keywordtype">void</span> on_open(<a name="_a2"></a><a class="code" href="classproton_1_1listener.html">proton::listener</a>&amp; l) OVERRIDE {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;listening on &quot;</span> &lt;&lt; l.<a name="a3"></a><a class="code" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">port</a>() &lt;&lt; std::endl;</div><div class="line">        }</div><div class="line">    };</div><div class="line"></div><div class="line">    std::string url;</div><div class="line">    <a class="code" href="classproton_1_1listener.html">proton::listener</a> listener;</di
 v><div class="line">    listener_ready_handler listen_handler;</div><div class="line">    <span class="keywordtype">int</span> sent;</div><div class="line">    <span class="keywordtype">int</span> confirmed;</div><div class="line">    <span class="keywordtype">int</span> total;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    simple_send(<span class="keyword">const</span> std::string &amp;s, <span class="keywordtype">int</span> c) : url(s), sent(0), confirmed(0), total(c) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_container_start(<a name="_a4"></a><a class="code" href="classproton_1_1container.html">proton::container</a> &amp;c) OVERRIDE {</div><div class="line">        listener = c.<a name="a5"></a><a class="code" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524">listen</a>(url, listen_handler);</div><div class="line">    }</div><div class="line">
 </div><div class="line">    <span class="keywordtype">void</span> on_sendable(<a name="_a6"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;sender) OVERRIDE {</div><div class="line">        <span class="keywordflow">while</span> (sender.<a name="a7"></a><a class="code" href="classproton_1_1link.html#afd27bd11ba72d7df51c44f71b15749eb">credit</a>() &amp;&amp; sent &lt; total) {</div><div class="line">            <a name="_a8"></a><a class="code" href="classproton_1_1message.html">proton::message</a> msg;</div><div class="line">            std::map&lt;std::string, int&gt; m;</div><div class="line">            m[<span class="stringliteral">&quot;sequence&quot;</span>] = sent + 1;</div><div class="line"></div><div class="line">            msg.<a name="a9"></a><a class="code" href="classproton_1_1message.html#a84811758e758988a802673edca6b77cb">id</a>(sent + 1);</div><div class="line">            msg.<a name="a10"></a><a class="code" href="classproton_1_1messa
 ge.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>(m);</div><div class="line"></div><div class="line">            sender.<a name="a11"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(msg);</div><div class="line">            sent++;</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_tracker_accept(<a name="_a12"></a><a class="code" href="classproton_1_1tracker.html">proton::tracker</a> &amp;t) OVERRIDE {</div><div class="line">        confirmed++;</div><div class="line"></div><div class="line">        <span class="keywordflow">if</span> (confirmed == total) {</div><div class="line">            std::cout &lt;&lt; <span class="stringliteral">&quot;all messages confirmed&quot;</span> &lt;&lt; std::endl;</div><div class="line">            t.<a name="a13"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e0738
 9a52">connection</a>().<a name="a14"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">            listener.<a name="a15"></a><a class="code" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a>();</div><div class="line">        }</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> on_transport_close(<a name="_a16"></a><a class="code" href="classproton_1_1transport.html">proton::transport</a> &amp;) OVERRIDE {</div><div class="line">        sent = confirmed;</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    std::string address(<span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>);</div><div
  class="line">    <span class="keywordtype">int</span> message_count = 100;</div><div class="line">    example::options opts(argc, argv);</div><div class="line"></div><div class="line">    opts.add_value(address, <span class="charliteral">&#39;a&#39;</span>, <span class="stringliteral">&quot;address&quot;</span>, <span class="stringliteral">&quot;listen and send on URL&quot;</span>, <span class="stringliteral">&quot;URL&quot;</span>);</div><div class="line">    opts.add_value(message_count, <span class="charliteral">&#39;m&#39;</span>, <span class="stringliteral">&quot;messages&quot;</span>, <span class="stringliteral">&quot;send COUNT messages&quot;</span>, <span class="stringliteral">&quot;COUNT&quot;</span>);</div><div class="line"></div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        opts.parse();</div><div class="line"></div><div class="line">        simple_send send(address, message_count);</div><div class="line">        <a class="co
 de" href="classproton_1_1container.html">proton::container</a>(send).<a name="a17"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> example::bad_option&amp; e) {</div><div class="line">        std::cout &lt;&lt; opts &lt;&lt; std::endl &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.html b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.html
index 6a84301..1baed06 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.html
@@ -145,6 +145,9 @@ duration&#160;</td><td class="memItemRight" valign="bottom"><b>operator*</b> (du
 <tr class="memitem:a80e1db1066d64c9e18890d42cad0b16f"><td class="memItemLeft" align="right" valign="top"><a id="a80e1db1066d64c9e18890d42cad0b16f"></a>
 duration&#160;</td><td class="memItemRight" valign="bottom"><b>operator*</b> (uint64_t n, duration d)</td></tr>
 <tr class="separator:a80e1db1066d64c9e18890d42cad0b16f"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aab017f43c97ab4bd9a41cf3de50a8993"><td class="memItemLeft" align="right" valign="top"><a id="aab017f43c97ab4bd9a41cf3de50a8993"></a>
+duration&#160;</td><td class="memItemRight" valign="bottom"><b>operator/</b> (duration d, uint64_t n)</td></tr>
+<tr class="separator:aab017f43c97ab4bd9a41cf3de50a8993"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A span of time in milliseconds. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.js b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.js
index ebae4ee..7200973 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp.js
@@ -7,5 +7,6 @@ var duration_8hpp =
     [ "operator+", "duration_8hpp.html#aed0da2778dd6e10e26e95a87d92c4a3d", null ],
     [ "operator-", "duration_8hpp.html#a7a3213826600a9c6f67f158eab0e287d", null ],
     [ "operator*", "duration_8hpp.html#ad3251c493ce2a91805b4bcc15d05a5f9", null ],
-    [ "operator*", "duration_8hpp.html#a80e1db1066d64c9e18890d42cad0b16f", null ]
+    [ "operator*", "duration_8hpp.html#a80e1db1066d64c9e18890d42cad0b16f", null ],
+    [ "operator/", "duration_8hpp.html#aab017f43c97ab4bd9a41cf3de50a8993", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp_source.html
index 824323e..f8cf0c8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/duration_8hpp_source.html
@@ -93,7 +93,8 @@ $(document).ready(function(){initNavTree('duration_8hpp_source.html','');});
 <div class="title">duration.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="duration_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DURATION_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DURATION_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor lice
 nse agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the
 </span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/comparable.hpp&quot;</span></div><div class="line"><a name="l00027"></a><
 span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;iosfwd&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a nam
 e="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html">   39</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1duration.html">duration</a> : <span class="keyword">private</span> internal::comparable&lt;duration&gt; {</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00042"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">   42</a></span>&#160;    <span class="keyword">typedef</span> int64_t <a class="code" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">numeric_type</a>;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00045"></a><span class="lineno"><a class="line" href="classp
 roton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">   45</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(numeric_type ms = 0) : ms_(ms) {}</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">   48</a></span>&#160;    <a class="code" href="classproton_1_1duration.html">duration</a>&amp; <a class="code" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">operator=</a>(numeric_type ms) { ms_ = ms; <span class="keywordflow">return</span> *<span class="keyword">this</span>; }</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#afb6
 516c796d13a88dcbd295247f0f535">   51</a></span>&#160;    numeric_type <a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> ms_; }</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">   53</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">FOREVER</a>;   </div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">   54</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span
 > <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">IMMEDIATE</a>; </div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">   55</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">SECOND</a>;    </div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">   56</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1
 duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">MINUTE</a>;    </div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;    numeric_type ms_;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;};</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;PN_CPP_EXTERN std::ostream&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(std::ostream&amp;, <a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno"> 
   67</span>&#160;<span class="keyword">inline</span> <span class="keywordtype">bool</span> operator&lt;(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() &lt; y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>(); }</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="keyword">inline</span> <span class="keywordtype">bool</span> operator==(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() == y.<a class="code" href="classproton_1
 _1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>(); }</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator+(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() + y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()); }</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="keyword">inline</span> <a class="code" href="classpro
 ton_1_1duration.html">duration</a> operator-(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() - y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()); }</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator*(<a class="code" href="classproton_1_1duration.html">duration</a> d, uint64_t n) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(d.<a class="code" href="classproton_1_1d
 uration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()*n); }</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator*(uint64_t n, <a class="code" href="classproton_1_1duration.html">duration</a> d) { <span class="keywordflow">return</span> d * n; }</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;<span class="preprocessor">#endif // PROTON_DURATION_HPP</span></div><div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a href="namespaceproton.html#ae6fabe30961a3d3280bb8445e74
 3b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
+<a href="duration_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DURATION_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DURATION_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor lice
 nse agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the
 </span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/comparable.hpp&quot;</span></div><div class="line"><a name="l00027"></a><
 span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="types__fwd_8hpp.html">./types_fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#include &lt;iosfwd&gt;</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a nam
 e="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00039"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html">   39</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1duration.html">duration</a> : <span class="keyword">private</span> internal::comparable&lt;duration&gt; {</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00042"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">   42</a></span>&#160;    <span class="keyword">typedef</span> int64_t <a class="code" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">numeric_type</a>;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;</div><div class="line"><a name="l00045"></a><span class="lineno"><a class="line" href="classp
 roton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">   45</a></span>&#160;    <span class="keyword">explicit</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(numeric_type ms = 0) : ms_(ms) {}</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">   48</a></span>&#160;    <a class="code" href="classproton_1_1duration.html">duration</a>&amp; <a class="code" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">operator=</a>(numeric_type ms) { ms_ = ms; <span class="keywordflow">return</span> *<span class="keyword">this</span>; }</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#afb6
 516c796d13a88dcbd295247f0f535">   51</a></span>&#160;    numeric_type <a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()<span class="keyword"> const </span>{ <span class="keywordflow">return</span> ms_; }</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">   53</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">FOREVER</a>;   </div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">   54</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span
 > <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">IMMEDIATE</a>; </div><div class="line"><a name="l00055"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">   55</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">SECOND</a>;    </div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">   56</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1
 duration.html#ad936986f8cf9cb95b0dbc93ade000b76">MILLISECOND</a>; </div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">   57</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">MINUTE</a>;    </div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;    numeric_type ms_;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;};</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="li
 ne"><a name="l00064"></a><span class="lineno">   64</span>&#160;PN_CPP_EXTERN std::ostream&amp; <a class="code" href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">operator&lt;&lt;</a>(std::ostream&amp;, <a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="keyword">inline</span> <span class="keywordtype">bool</span> operator&lt;(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() &lt; y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>(); }</div><div class="line"><a name="l00069"></a><span class="linen
 o">   69</span>&#160;<span class="keyword">inline</span> <span class="keywordtype">bool</span> operator==(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() == y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>(); }</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator+(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1
 duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() + y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()); }</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator-(<a class="code" href="classproton_1_1duration.html">duration</a> x, <a class="code" href="classproton_1_1duration.html">duration</a> y) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(x.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() - y.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()); }</div><div class="line"><
 a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator*(<a class="code" href="classproton_1_1duration.html">duration</a> d, uint64_t n) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(d.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>()*n); }</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.html">duration</a> operator*(uint64_t n, <a class="code" href="classproton_1_1duration.html">duration</a> d) { <span class="keywordflow">return</span> d * n; }</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="keyword">inline</span> <a class="code" href="classproton_1_1duration.htm
 l">duration</a> operator/(<a class="code" href="classproton_1_1duration.html">duration</a> d, uint64_t n) { <span class="keywordflow">return</span> <a class="code" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(d.<a class="code" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() / n); }</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;<span class="preprocessor">#endif // PROTON_DURATION_HPP</span></div><div class="ttc" id="classproton_1_1duration_html_ad936986f8cf9cb95b0dbc93ade000b76"><div class="ttname"><a href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">proton::durat
 ion::MILLISECOND</a></div><div class="ttdeci">static const duration MILLISECOND</div><div class="ttdoc">One millisecond. </div><div class="ttdef"><b>Definition:</b> duration.hpp:56</div></div>
+<div class="ttc" id="namespaceproton_html_ae6fabe30961a3d3280bb8445e743b21c"><div class="ttname"><a href="namespaceproton.html#ae6fabe30961a3d3280bb8445e743b21c">proton::operator&lt;&lt;</a></div><div class="ttdeci">std::ostream &amp; operator&lt;&lt;(std::ostream &amp;, const binary &amp;)</div><div class="ttdoc">Print a binary value. </div></div>
 <div class="ttc" id="classproton_1_1duration_html_aa4fb0163afbe72b04236e39e2b6d2dbf"><div class="ttname"><a href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">proton::duration::duration</a></div><div class="ttdeci">duration(numeric_type ms=0)</div><div class="ttdoc">Construct from a value in milliseconds. </div><div class="ttdef"><b>Definition:</b> duration.hpp:45</div></div>
 <div class="ttc" id="classproton_1_1duration_html"><div class="ttname"><a href="classproton_1_1duration.html">proton::duration</a></div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> duration.hpp:39</div></div>
 <div class="ttc" id="classproton_1_1duration_html_ab804de8e95dd6203d6e72e797440055e"><div class="ttname"><a href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">proton::duration::IMMEDIATE</a></div><div class="ttdeci">static const duration IMMEDIATE</div><div class="ttdoc">Don&amp;#39;t wait at all. </div><div class="ttdef"><b>Definition:</b> duration.hpp:54</div></div>
@@ -102,7 +103,7 @@ $(document).ready(function(){initNavTree('duration_8hpp_source.html','');});
 <div class="ttc" id="classproton_1_1duration_html_a44829e89515fec974f57f37bbdbfaeb2"><div class="ttname"><a href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">proton::duration::numeric_type</a></div><div class="ttdeci">int64_t numeric_type</div><div class="ttdoc">A numeric type holding a value in milliseconds. </div><div class="ttdef"><b>Definition:</b> duration.hpp:42</div></div>
 <div class="ttc" id="classproton_1_1duration_html_aced1c394edccf069b2748d46965fb562"><div class="ttname"><a href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">proton::duration::SECOND</a></div><div class="ttdeci">static const duration SECOND</div><div class="ttdoc">One second. </div><div class="ttdef"><b>Definition:</b> duration.hpp:55</div></div>
 <div class="ttc" id="classproton_1_1duration_html_a13ff6465e0979fe301b75ea574ce2304"><div class="ttname"><a href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">proton::duration::operator=</a></div><div class="ttdeci">duration &amp; operator=(numeric_type ms)</div><div class="ttdoc">Assign a value in milliseconds. </div><div class="ttdef"><b>Definition:</b> duration.hpp:48</div></div>
-<div class="ttc" id="classproton_1_1duration_html_a437a5e5f6a7d0c8780f3594b2272cba0"><div class="ttname"><a href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">proton::duration::MINUTE</a></div><div class="ttdeci">static const duration MINUTE</div><div class="ttdoc">One minute. </div><div class="ttdef"><b>Definition:</b> duration.hpp:56</div></div>
+<div class="ttc" id="classproton_1_1duration_html_a437a5e5f6a7d0c8780f3594b2272cba0"><div class="ttname"><a href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">proton::duration::MINUTE</a></div><div class="ttdeci">static const duration MINUTE</div><div class="ttdoc">One minute. </div><div class="ttdef"><b>Definition:</b> duration.hpp:57</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 <div class="ttc" id="classproton_1_1duration_html_acebdd3ee364870f89665ca128e97a4d7"><div class="ttname"><a href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">proton::duration::FOREVER</a></div><div class="ttdeci">static const duration FOREVER</div><div class="ttdoc">Wait forever. </div><div class="ttdef"><b>Definition:</b> duration.hpp:53</div></div>
 </div><!-- fragment --></div><!-- contents -->


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


[30/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/pages.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/pages.html b/content/releases/qpid-proton-master/proton/c/api/pages.html
index cf25b0a..bb23056 100755
--- a/content/releases/qpid-proton-master/proton/c/api/pages.html
+++ b/content/releases/qpid-proton-master/proton/c/api/pages.html
@@ -96,6 +96,7 @@ $(document).ready(function(){initNavTree('pages.html','');});
 <div class="textblock">Here is a list of all related documentation pages:</div><div class="directory">
 <table class="directory">
 <tr id="row_0_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><a class="el" href="io_page.html" target="_self">IO integration</a></td><td class="desc"></td></tr>
+<tr id="row_1_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><a class="el" href="deprecated.html" target="_self">Deprecated List</a></td><td class="desc"></td></tr>
 </table>
 </div><!-- directory -->
 </div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/proactor_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/proactor_8h.html b/content/releases/qpid-proton-master/proton/c/api/proactor_8h.html
index c08d3c5..a27dec8 100755
--- a/content/releases/qpid-proton-master/proton/c/api/proactor_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/proactor_8h.html
@@ -116,7 +116,7 @@ Macros</h2></td></tr>
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="func-members"></a>
 Functions</h2></td></tr>
 <tr class="memitem:gaf67a7642c9003b36255b58776b494c96"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a> (char *addr, size_t size, const char *host, const char *port)</td></tr>
-<tr class="memdesc:gaf67a7642c9003b36255b58776b494c96"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6" title="Bind connection to a new Transport connected to addr. ">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>  <a href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">More...</a><br /></td></tr>
+<tr class="memdesc:gaf67a7642c9003b36255b58776b494c96"><td class="mdescLeft">&#160;</td><td class="mdescRight">Format a host:port address string for <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect()</a> or <a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752" title="Start listening for incoming connections. ">pn_proactor_listen()</a>  <a href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">More...</a><br /></td></tr>
 <tr class="separator:gaf67a7642c9003b36255b58776b494c96"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac2a925b3de00efd8cd40fa9920169554"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN <a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a> (void)</td></tr>
 <tr class="memdesc:gac2a925b3de00efd8cd40fa9920169554"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a proactor.  <a href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">More...</a><br /></td></tr>
@@ -124,8 +124,10 @@ Functions</h2></td></tr>
 <tr class="memitem:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor)</td></tr>
 <tr class="memdesc:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="mdescLeft">&#160;</td><td class="mdescRight">Free the proactor.  <a href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">More...</a><br /></td></tr>
 <tr class="separator:ga5260c2653d4af5eb2f1c8c6190e9d6cf"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:gabb093e51449351cf5530bb300bd67ba1"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">pn_proactor_connect2</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *addr)</td></tr>
+<tr class="memdesc:gabb093e51449351cf5530bb300bd67ba1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Connect <code>transport</code> to <code>addr</code> and bind to <code>connection</code>.  <a href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">More...</a><br /></td></tr>
+<tr class="separator:gabb093e51449351cf5530bb300bd67ba1"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, const char *addr)</td></tr>
-<tr class="memdesc:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Bind <code>connection</code> to a new <a class="el" href="group__transport.html">Transport</a> connected to <code>addr</code>.  <a href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">More...</a><br /></td></tr>
 <tr class="separator:ga9a9d1c4138226fa87160f4769b87f8e6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gacbed6a4ab75ef8452c10d52e4cd62752"><td class="memItemLeft" align="right" valign="top">PNP_EXTERN void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a> (<a class="el" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="el" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, const char *addr, int backlog)</td></tr>
 <tr class="memdesc:gacbed6a4ab75ef8452c10d52e4cd62752"><td class="mdescLeft">&#160;</td><td class="mdescRight">Start listening for incoming connections.  <a href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">More...</a><br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/proactor_8h.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/proactor_8h.js b/content/releases/qpid-proton-master/proton/c/api/proactor_8h.js
index 197e3a4..619b94c 100755
--- a/content/releases/qpid-proton-master/proton/c/api/proactor_8h.js
+++ b/content/releases/qpid-proton-master/proton/c/api/proactor_8h.js
@@ -4,6 +4,7 @@ var proactor_8h =
     [ "pn_proactor_addr", "group__proactor.html#gaf67a7642c9003b36255b58776b494c96", null ],
     [ "pn_proactor", "group__proactor.html#gac2a925b3de00efd8cd40fa9920169554", null ],
     [ "pn_proactor_free", "group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf", null ],
+    [ "pn_proactor_connect2", "group__proactor.html#gabb093e51449351cf5530bb300bd67ba1", null ],
     [ "pn_proactor_connect", "group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6", null ],
     [ "pn_proactor_listen", "group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752", null ],
     [ "pn_proactor_disconnect", "group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68", null ],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/proactor_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/proactor_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/proactor_8h_source.html
index 2bd4983..afc27f1 100755
--- a/content/releases/qpid-proton-master/proton/c/api/proactor_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/proactor_8h_source.html
@@ -93,20 +93,22 @@ $(document).ready(function(){initNavTree('proactor_8h_source.html','');});
 <div class="title">proactor.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="proactor_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_PROACTOR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_PROACTOR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</spa
 n>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * spe
 cific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="l
 ineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno"><a class="line" href="group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256">   74</a></span>&#160;<span class="preprocessor">#define PN_MAX_ADDR 1060</span></div><div class="line"><a name="l00075"></
 a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;PNP_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a>(<span class="keywordtype">char</span> *addr, <span class="keywordtype">size_t</span> size, <span class="keyword">const</span> <span class="keywordtype">char</span> *host, <span class="keyword">const</span> <span class="keywordtype">char</span> *port);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00092"></a><span class="line
 no">   92</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *addr);</div><div c
 lass="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <span class="keyword">const</span> <span class="keywordtype">char</span> *addr, <span class="keywordtype">int</span> backlog);</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68">pn_proactor_disconnect</a>(<a class="code" href="gro
 up__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *condition);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;PNP_EXTERN <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *<a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;</div><div class="line"><a name="l00190"></a><span class="lineno">  190</span>&#160;PNP_EXTERN <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *<a class="code" href="group__proactor.htm
 l#ga957eae24db6ec4962af79c5a06106115">pn_proactor_get</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00191"></a><span class="lineno">  191</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events);</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711">pn_p
 roactor_interrupt</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00214"></a><span class="lineno">  214</span>&#160;</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32">pn_proactor_set_timeout</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> timeout);</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f">pn_proactor_cancel_timeout</a>(<a
  class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27">pn_proactor_release_connection</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560">pn_connection_wake</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div cl
 ass="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40">pn_connection_proactor</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__proactor.html#gac412771217decd84bd70931acbd0828a">pn_event_proactor</a>(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00
 285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;PNP_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d">pn_proactor_now</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;</div><div class="line"><a name="l00355"></a><span class="lineno">  355</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00356"></a><span class="lineno">  356</span>&#160;}</div><div class="line"><a name="l00357"></a><span class="lineno">  357</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00358"></a><span class="lineno">  358</span>&#160;</div><div class="line"><a name="l00359"></a><span class="lineno">  359</span>&#160;<span class="preproces
 sor">#endif </span><span class="comment">/* proactor.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> types.h:422</div></div>
+<a href="proactor_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_PROACTOR_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_PROACTOR_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</spa
 n>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * spe
 cific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="condition_8h.html">proton/condition.h</a>&gt;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="l
 ineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno"><a class="line" href="group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256">   74</a></span>&#160;<span class="preprocessor">#define PN_MAX_ADDR 1060</span></div><div class="line"><a name="l00075"></
 a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;PNP_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a>(<span class="keywordtype">char</span> *addr, <span class="keywordtype">size_t</span> size, <span class="keyword">const</span> <span class="keywordtype">char</span> *host, <span class="keyword">const</span> <span class="keywordtype">char</span> *port);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00092"></a><span class="line
 no">   92</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">pn_proactor_connect2</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transpor
 t_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *addr);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection, <span class="keyword">const</span> <span class="keywordtype">char</span> *addr);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gacbed6a4ab75ef
 8452c10d52e4cd62752">pn_proactor_listen</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__listener.html#ga68ac7072ae60612d0bca5470014bf216">pn_listener_t</a> *listener, <span class="keyword">const</span> <span class="keywordtype">char</span> *addr, <span class="keywordtype">int</span> backlog);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68">pn_proactor_disconnect</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *condition);</div><div class="line"><a name="l00181"></a><span class="lineno">  1
 81</span>&#160;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;PNP_EXTERN <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *<a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;PNP_EXTERN <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *<a class="code" href="group__proactor.html#ga957eae24db6ec4962af79c5a06106115">pn_proactor_get</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;</div><div cl
 ass="line"><a name="l00216"></a><span class="lineno">  216</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events);</div><div class="line"><a name="l00217"></a><span class="lineno">  217</span>&#160;</div><div class="line"><a name="l00229"></a><span class="lineno">  229</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711">pn_proactor_interrupt</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00230"></a><span class="lineno">  230</span>&#160;</div><div class="line"><a name="l00241"></a><spa
 n class="lineno">  241</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32">pn_proactor_set_timeout</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor, <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> timeout);</div><div class="line"><a name="l00242"></a><span class="lineno">  242</span>&#160;</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f">pn_proactor_cancel_timeout</a>(<a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor);</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</
 span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27">pn_proactor_release_connection</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00281"></a><span class="lineno">  281</span>&#160;PNP_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560">pn_connection_wake</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00282"></a><span class="lineno">  282</span>&#160;</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> 
 *<a class="code" href="group__proactor.html#ga4727a4e26f19efcff0d48960cbba2f40">pn_connection_proactor</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00291"></a><span class="lineno">  291</span>&#160;</div><div class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;PNP_EXTERN <a class="code" href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *<a class="code" href="group__proactor.html#gac412771217decd84bd70931acbd0828a">pn_event_proactor</a>(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *event);</div><div class="line"><a name="l00300"></a><span class="lineno">  300</span>&#160;</div><div class="line"><a name="l00313"></a><span class="lineno">  313</span>&#160;PNP_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a> <a class="code" href="g
 roup__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d">pn_proactor_now</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00314"></a><span class="lineno">  314</span>&#160;</div><div class="line"><a name="l00370"></a><span class="lineno">  370</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00371"></a><span class="lineno">  371</span>&#160;}</div><div class="line"><a name="l00372"></a><span class="lineno">  372</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00373"></a><span class="lineno">  373</span>&#160;</div><div class="line"><a name="l00374"></a><span class="lineno">  374</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* proactor.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__listener_html_ga68ac7072ae60612d0bca5470014bf216"><div class="ttname"><a href="group__listener.html#ga68ac7072ae60612d0bca5470014bf
 216">pn_listener_t</a></div><div class="ttdeci">struct pn_listener_t pn_listener_t</div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> types.h:420</div></div>
 <div class="ttc" id="group__proactor_html_gaf67a7642c9003b36255b58776b494c96"><div class="ttname"><a href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a></div><div class="ttdeci">PNP_EXTERN int pn_proactor_addr(char *addr, size_t size, const char *host, const char *port)</div><div class="ttdoc">Format a host:port address string for pn_proactor_connect() or pn_proactor_listen() ...</div></div>
-<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:147</div></div>
+<div class="ttc" id="group__api__types_html_ga9a701bc6dc9af9f42c3f4679172a723c"><div class="ttname"><a href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="ttdeci">uint32_t pn_millis_t</div><div class="ttdoc">A span of time in milliseconds. </div><div class="ttdef"><b>Definition:</b> types.h:145</div></div>
 <div class="ttc" id="group__proactor_html_ga2b66a46f3e557010ec61bd105326753d"><div class="ttname"><a href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a></div><div class="ttdeci">PNP_EXTERN pn_event_batch_t * pn_proactor_wait(pn_proactor_t *proactor)</div><div class="ttdoc">Wait until there are Proactor events to handle. </div></div>
 <div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__event_html_ga6bc581dfeaa8e8d46d07d37229d565c9"><div class="ttname"><a href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a></div><div class="ttdeci">struct pn_event_batch_t pn_event_batch_t</div><div class="ttdoc">Unsettled API - A batch of events that must be handled in sequence. </div><div class="ttdef"><b>Definition:</b> event.h:547</div></div>
 <div class="ttc" id="group__proactor_html_gaa5255cd1bcb5d7f5639b53dc30712711"><div class="ttname"><a href="group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711">pn_proactor_interrupt</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_interrupt(pn_proactor_t *proactor)</div><div class="ttdoc">Return a PN_PROACTOR_INTERRUPT event as soon as possible. </div></div>
+<div class="ttc" id="group__proactor_html_gabb093e51449351cf5530bb300bd67ba1"><div class="ttname"><a href="group__proactor.html#gabb093e51449351cf5530bb300bd67ba1">pn_proactor_connect2</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_connect2(pn_proactor_t *proactor, pn_connection_t *connection, pn_transport_t *transport, const char *addr)</div><div class="ttdoc">Connect transport to addr and bind to connection. </div></div>
 <div class="ttc" id="group__proactor_html_gac600bd88ed0fc6c2b66bed4a8740bd68"><div class="ttname"><a href="group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68">pn_proactor_disconnect</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_disconnect(pn_proactor_t *proactor, pn_condition_t *condition)</div><div class="ttdoc">Disconnect all connections and listeners belonging to the proactor. </div></div>
 <div class="ttc" id="group__proactor_html_gad7cd71f06282eb290699d90c316b2d32"><div class="ttname"><a href="group__proactor.html#gad7cd71f06282eb290699d90c316b2d32">pn_proactor_set_timeout</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_set_timeout(pn_proactor_t *proactor, pn_millis_t timeout)</div><div class="ttdoc">Return a PN_PROACTOR_TIMEOUT after timeout milliseconds elapse. </div></div>
-<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:440</div></div>
+<div class="ttc" id="group__proactor_html_gabba42c7929dfceb9d296535bad0c93dc"><div class="ttname"><a href="group__proactor.html#gabba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a></div><div class="ttdeci">struct pn_proactor_t pn_proactor_t</div><div class="ttdoc">A harness for multithreaded IO. </div><div class="ttdef"><b>Definition:</b> types.h:438</div></div>
 <div class="ttc" id="condition_8h_html"><div class="ttname"><a href="condition_8h.html">condition.h</a></div><div class="ttdoc">An endpoint error state. </div></div>
 <div class="ttc" id="group__proactor_html_gac412771217decd84bd70931acbd0828a"><div class="ttname"><a href="group__proactor.html#gac412771217decd84bd70931acbd0828a">pn_event_proactor</a></div><div class="ttdeci">PNP_EXTERN pn_proactor_t * pn_event_proactor(pn_event_t *event)</div><div class="ttdoc">Return the proactor associated with an event. </div></div>
 <div class="ttc" id="group__proactor_html_ga0f49c771fe3bff54f58c9d583ca30560"><div class="ttname"><a href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560">pn_connection_wake</a></div><div class="ttdeci">PNP_EXTERN void pn_connection_wake(pn_connection_t *connection)</div><div class="ttdoc">Return a PN_CONNECTION_WAKE event for connection as soon as possible. </div></div>
-<div class="ttc" id="group__proactor_html_ga9a9d1c4138226fa87160f4769b87f8e6"><div class="ttname"><a href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_connect(pn_proactor_t *proactor, pn_connection_t *connection, const char *addr)</div><div class="ttdoc">Bind connection to a new Transport connected to addr. </div></div>
+<div class="ttc" id="group__proactor_html_ga9a9d1c4138226fa87160f4769b87f8e6"><div class="ttname"><a href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_connect(pn_proactor_t *proactor, pn_connection_t *connection, const char *addr)</div></div>
 <div class="ttc" id="group__proactor_html_gacbed6a4ab75ef8452c10d52e4cd62752"><div class="ttname"><a href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_listen(pn_proactor_t *proactor, pn_listener_t *listener, const char *addr, int backlog)</div><div class="ttdoc">Start listening for incoming connections. </div></div>
 <div class="ttc" id="group__proactor_html_gac2a925b3de00efd8cd40fa9920169554"><div class="ttname"><a href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a></div><div class="ttdeci">PNP_EXTERN pn_proactor_t * pn_proactor(void)</div><div class="ttdoc">Create a proactor. </div></div>
 <div class="ttc" id="group__proactor_html_gad45b60b98f2bf385ee6ca5dca7b3f42d"><div class="ttname"><a href="group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d">pn_proactor_now</a></div><div class="ttdeci">PNP_EXTERN pn_millis_t pn_proactor_now(void)</div><div class="ttdoc">Get the real elapsed time since an arbitrary point in the past in milliseconds. </div></div>
@@ -116,7 +118,7 @@ $(document).ready(function(){initNavTree('proactor_8h_source.html','');});
 <div class="ttc" id="group__proactor_html_gade60ff2292b74841766f953b906285c0"><div class="ttname"><a href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_done(pn_proactor_t *proactor, pn_event_batch_t *events)</div><div class="ttdoc">Call when finished handling a batch of events. </div></div>
 <div class="ttc" id="group__proactor_html_ga957eae24db6ec4962af79c5a06106115"><div class="ttname"><a href="group__proactor.html#ga957eae24db6ec4962af79c5a06106115">pn_proactor_get</a></div><div class="ttdeci">PNP_EXTERN pn_event_batch_t * pn_proactor_get(pn_proactor_t *proactor)</div><div class="ttdoc">Return Proactor events if any are available immediately. </div></div>
 <div class="ttc" id="event_8h_html"><div class="ttname"><a href="event_8h.html">event.h</a></div><div class="ttdoc">Protocol and transport events. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__condition_html_ga11eb7db7d2c205169fe3d47c996a95a5"><div class="ttname"><a href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a></div><div class="ttdeci">struct pn_condition_t pn_condition_t</div><div class="ttdoc">An AMQP Condition object. </div><div class="ttdef"><b>Definition:</b> condition.h:64</div></div>
 <div class="ttc" id="group__proactor_html_ga1950236260353f82729dbb4589ef6c27"><div class="ttname"><a href="group__proactor.html#ga1950236260353f82729dbb4589ef6c27">pn_proactor_release_connection</a></div><div class="ttdeci">PNP_EXTERN void pn_proactor_release_connection(pn_connection_t *connection)</div><div class="ttdoc">Release ownership of connection, disassociate it from its proactor. </div></div>
 <div class="ttc" id="group__event_html_ga87f3028b4888632bbd56fb71ac737ae8"><div class="ttname"><a href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a></div><div class="ttdeci">struct pn_event_t pn_event_t</div><div class="ttdoc">Notification of a state change in the protocol engine. </div><div class="ttdef"><b>Definition:</b> event.h:75</div></div>


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


[27/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/all_8.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/all_8.js b/content/releases/qpid-proton-master/proton/c/api/search/all_8.js
index 63b4a38..c632b0a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/all_8.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/all_8.js
@@ -1,5 +1,6 @@
 var searchData=
 [
+  ['pn_5faborted',['PN_ABORTED',['../group__error.html#ga82db456291c2627e31becc44b733a7f0',1,'error.h']]],
   ['pn_5faccepted',['PN_ACCEPTED',['../group__delivery.html#gac64952b813a707586c6b3898e09552e4',1,'disposition.h']]],
   ['pn_5farg_5ferr',['PN_ARG_ERR',['../group__error.html#ga5551b7172de89dc540bd7c2beedd325a',1,'error.h']]],
   ['pn_5farray',['PN_ARRAY',['../group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba2c6f15d0ad9e27f040382ef4a2be807d',1,'codec.h']]],
@@ -58,6 +59,7 @@ var searchData=
   ['pn_5fconnection_5fdriver_5flog',['pn_connection_driver_log',['../group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5flogf',['pn_connection_driver_logf',['../group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fnext_5fevent',['pn_connection_driver_next_event',['../group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5',1,'connection_driver.h']]],
+  ['pn_5fconnection_5fdriver_5fptr',['pn_connection_driver_ptr',['../group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fbuffer',['pn_connection_driver_read_buffer',['../group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fclose',['pn_connection_driver_read_close',['../group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fclosed',['pn_connection_driver_read_closed',['../group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23',1,'connection_driver.h']]],
@@ -103,7 +105,7 @@ var searchData=
   ['pn_5fconnection_5ft',['pn_connection_t',['../group__connection.html#ga886351d81ff3a977a284a206526c5aff',1,'types.h']]],
   ['pn_5fconnection_5ftransport',['pn_connection_transport',['../group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59',1,'connection.h']]],
   ['pn_5fconnection_5funbound',['PN_CONNECTION_UNBOUND',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498',1,'event.h']]],
-  ['pn_5fconnection_5fwake',['PN_CONNECTION_WAKE',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0',1,'PN_CONNECTION_WAKE():&#160;event.h'],['../group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560',1,'pn_connection_wake(pn_connection_t *connection):&#160;proactor.h']]],
+  ['pn_5fconnection_5fwake',['pn_connection_wake',['../group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560',1,'pn_connection_wake(pn_connection_t *connection):&#160;proactor.h'],['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0',1,'PN_CONNECTION_WAKE():&#160;event.h']]],
   ['pn_5fcoordinator',['PN_COORDINATOR',['../group__terminus.html#gga3cb9c86d1e2bb024de2658f9def098e7a75bb94f03973a939835d98e9b1999aae',1,'terminus.h']]],
   ['pn_5fcumulative',['PN_CUMULATIVE',['../group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9',1,'messenger.h']]],
   ['pn_5fdata',['pn_data',['../group__data.html#gac21c6f1c517ac486e2923baa3d0c5db4',1,'codec.h']]],
@@ -343,7 +345,9 @@ var searchData=
   ['pn_5flink_5funsettled',['pn_link_unsettled',['../group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1',1,'link.h']]],
   ['pn_5flist',['PN_LIST',['../group__amqp__types.html#gga4465b5ea7d3c4f15c1dffa4deda905dba653d98ae82ff7048973b4c755d2b2804',1,'codec.h']]],
   ['pn_5flistener',['pn_listener',['../group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5',1,'listener.h']]],
-  ['pn_5flistener_5faccept',['PN_LISTENER_ACCEPT',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c',1,'PN_LISTENER_ACCEPT():&#160;event.h'],['../group__listener.html#gaaee3c3f3822484bc2e370406abf5b736',1,'pn_listener_accept(pn_listener_t *, pn_connection_t *):&#160;listener.h']]],
+  ['pn_5flistener_5faccept',['PN_LISTENER_ACCEPT',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c',1,'PN_LISTENER_ACCEPT():&#160;event.h'],['../group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9',1,'pn_listener_accept(pn_listener_t *listener, pn_connection_t *connection):&#160;listener.h']]],
+  ['pn_5flistener_5faccept2',['pn_listener_accept2',['../group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070',1,'listener.h']]],
+  ['pn_5flistener_5faddr',['pn_listener_addr',['../group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9',1,'netaddr.h']]],
   ['pn_5flistener_5fattachments',['pn_listener_attachments',['../group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f',1,'listener.h']]],
   ['pn_5flistener_5fclose',['PN_LISTENER_CLOSE',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca',1,'PN_LISTENER_CLOSE():&#160;event.h'],['../group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104',1,'pn_listener_close(pn_listener_t *l):&#160;listener.h']]],
   ['pn_5flistener_5fcondition',['pn_listener_condition',['../group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2',1,'listener.h']]],
@@ -391,6 +395,7 @@ var searchData=
   ['pn_5fmessage_5fis_5ffirst_5facquirer',['pn_message_is_first_acquirer',['../group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2',1,'message.h']]],
   ['pn_5fmessage_5fis_5finferred',['pn_message_is_inferred',['../group__message.html#ga5d9367609d74ca3511d4172806eeb55b',1,'message.h']]],
   ['pn_5fmessage_5fproperties',['pn_message_properties',['../group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad',1,'message.h']]],
+  ['pn_5fmessage_5fsend',['pn_message_send',['../group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5',1,'message.h']]],
   ['pn_5fmessage_5fset_5faddress',['pn_message_set_address',['../group__message.html#ga38ecee233f94e128bed9be3e530f27e5',1,'message.h']]],
   ['pn_5fmessage_5fset_5fcontent_5fencoding',['pn_message_set_content_encoding',['../group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b',1,'message.h']]],
   ['pn_5fmessage_5fset_5fcontent_5ftype',['pn_message_set_content_type',['../group__message.html#gaa0247560f0cd4590bc8ece20565eb611',1,'message.h']]],
@@ -474,7 +479,10 @@ var searchData=
   ['pn_5fmillis_5fmax',['PN_MILLIS_MAX',['../group__api__types.html#ga46d74369b8b364df95fd7cfa843f6d64',1,'types.h']]],
   ['pn_5fmillis_5ft',['pn_millis_t',['../group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c',1,'types.h']]],
   ['pn_5fmodified',['PN_MODIFIED',['../group__delivery.html#ga247e3d1ac7c9096cdd28424353582962',1,'disposition.h']]],
+  ['pn_5fnetaddr_5fhost_5fport',['pn_netaddr_host_port',['../group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b',1,'netaddr.h']]],
+  ['pn_5fnetaddr_5flistening',['pn_netaddr_listening',['../group__proactor.html#ga955471a53dd486a6f227d8d57322a44c',1,'netaddr.h']]],
   ['pn_5fnetaddr_5flocal',['pn_netaddr_local',['../group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b',1,'netaddr.h']]],
+  ['pn_5fnetaddr_5fnext',['pn_netaddr_next',['../group__proactor.html#ga6163449ac3b87782628448f192930eb0',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fremote',['pn_netaddr_remote',['../group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fsockaddr',['pn_netaddr_sockaddr',['../group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fsocklen',['pn_netaddr_socklen',['../group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c',1,'netaddr.h']]],
@@ -489,12 +497,13 @@ var searchData=
   ['pn_5fproactor_5faddr',['pn_proactor_addr',['../group__proactor.html#gaf67a7642c9003b36255b58776b494c96',1,'proactor.h']]],
   ['pn_5fproactor_5fcancel_5ftimeout',['pn_proactor_cancel_timeout',['../group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f',1,'proactor.h']]],
   ['pn_5fproactor_5fconnect',['pn_proactor_connect',['../group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6',1,'proactor.h']]],
+  ['pn_5fproactor_5fconnect2',['pn_proactor_connect2',['../group__proactor.html#gabb093e51449351cf5530bb300bd67ba1',1,'proactor.h']]],
   ['pn_5fproactor_5fdisconnect',['pn_proactor_disconnect',['../group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68',1,'proactor.h']]],
   ['pn_5fproactor_5fdone',['pn_proactor_done',['../group__proactor.html#gade60ff2292b74841766f953b906285c0',1,'proactor.h']]],
   ['pn_5fproactor_5ffree',['pn_proactor_free',['../group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf',1,'proactor.h']]],
   ['pn_5fproactor_5fget',['pn_proactor_get',['../group__proactor.html#ga957eae24db6ec4962af79c5a06106115',1,'proactor.h']]],
   ['pn_5fproactor_5finactive',['PN_PROACTOR_INACTIVE',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b',1,'event.h']]],
-  ['pn_5fproactor_5finterrupt',['PN_PROACTOR_INTERRUPT',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499',1,'PN_PROACTOR_INTERRUPT():&#160;event.h'],['../group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711',1,'pn_proactor_interrupt(pn_proactor_t *proactor):&#160;proactor.h']]],
+  ['pn_5fproactor_5finterrupt',['pn_proactor_interrupt',['../group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711',1,'pn_proactor_interrupt(pn_proactor_t *proactor):&#160;proactor.h'],['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499',1,'PN_PROACTOR_INTERRUPT():&#160;event.h']]],
   ['pn_5fproactor_5flisten',['pn_proactor_listen',['../group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752',1,'proactor.h']]],
   ['pn_5fproactor_5fnow',['pn_proactor_now',['../group__proactor.html#gad45b60b98f2bf385ee6ca5dca7b3f42d',1,'proactor.h']]],
   ['pn_5fproactor_5frelease_5fconnection',['pn_proactor_release_connection',['../group__proactor.html#ga1950236260353f82729dbb4589ef6c27',1,'proactor.h']]],
@@ -578,8 +587,10 @@ var searchData=
   ['pn_5fssl_5fdomain',['pn_ssl_domain',['../group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fallow_5funsecured_5fclient',['pn_ssl_domain_allow_unsecured_client',['../group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5ffree',['pn_ssl_domain_free',['../group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d',1,'ssl.h']]],
+  ['pn_5fssl_5fdomain_5fset_5fciphers',['pn_ssl_domain_set_ciphers',['../group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5fcredentials',['pn_ssl_domain_set_credentials',['../group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5fpeer_5fauthentication',['pn_ssl_domain_set_peer_authentication',['../group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11',1,'ssl.h']]],
+  ['pn_5fssl_5fdomain_5fset_5fprotocols',['pn_ssl_domain_set_protocols',['../group__ssl.html#ga333fcb941ed20421373f37b23d84fc98',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5ftrusted_5fca_5fdb',['pn_ssl_domain_set_trusted_ca_db',['../group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5ft',['pn_ssl_domain_t',['../group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175',1,'ssl.h']]],
   ['pn_5fssl_5fget_5fcert_5ffingerprint',['pn_ssl_get_cert_fingerprint',['../group__ssl.html#ga324db5da83b1abad2e948481d65119d4',1,'ssl.h']]],
@@ -657,14 +668,14 @@ var searchData=
   ['pn_5ftrace_5ft',['pn_trace_t',['../group__transport.html#ga4695788da8491f0c7104bfe36634ff94',1,'transport.h']]],
   ['pn_5ftracer_5ft',['pn_tracer_t',['../group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3',1,'transport.h']]],
   ['pn_5ftracker_5ft',['pn_tracker_t',['../group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7',1,'messenger.h']]],
-  ['pn_5ftransport',['pn_transport',['../group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77',1,'pn_transport(void):&#160;transport.h'],['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76',1,'PN_TRANSPORT():&#160;event.h']]],
+  ['pn_5ftransport',['PN_TRANSPORT',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76',1,'PN_TRANSPORT():&#160;event.h'],['../group__transport.html#gaf9833d93faf6a6ed68039e4a909cdd77',1,'pn_transport(void):&#160;transport.h']]],
   ['pn_5ftransport_5fattachments',['pn_transport_attachments',['../group__transport.html#gabdd6d56837a028097b1676350d65a864',1,'transport.h']]],
   ['pn_5ftransport_5fauthenticated',['PN_TRANSPORT_AUTHENTICATED',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaa205271edd307e5d33bd8287a760ad28',1,'event.h']]],
   ['pn_5ftransport_5fbind',['pn_transport_bind',['../group__transport.html#ga1a769e2e6c900c78c710407296cb4e13',1,'transport.h']]],
   ['pn_5ftransport_5fcapacity',['pn_transport_capacity',['../group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333',1,'transport.h']]],
   ['pn_5ftransport_5fclose_5fhead',['pn_transport_close_head',['../group__transport.html#gab8d0c7878d3d8ecda627678a6ec55072',1,'transport.h']]],
   ['pn_5ftransport_5fclose_5ftail',['pn_transport_close_tail',['../group__transport.html#gaa8304f8719610e384aa9a3f5f3c98289',1,'transport.h']]],
-  ['pn_5ftransport_5fclosed',['pn_transport_closed',['../group__transport.html#ga55c589d9b3e69057b130036c3c2173df',1,'pn_transport_closed(pn_transport_t *transport):&#160;transport.h'],['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba',1,'PN_TRANSPORT_CLOSED():&#160;event.h']]],
+  ['pn_5ftransport_5fclosed',['PN_TRANSPORT_CLOSED',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba',1,'PN_TRANSPORT_CLOSED():&#160;event.h'],['../group__transport.html#ga55c589d9b3e69057b130036c3c2173df',1,'pn_transport_closed(pn_transport_t *transport):&#160;transport.h']]],
   ['pn_5ftransport_5fcondition',['pn_transport_condition',['../group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34',1,'transport.h']]],
   ['pn_5ftransport_5fconnection',['pn_transport_connection',['../group__transport.html#ga2b98f594e012c24e7b17dcc91e3d4caf',1,'transport.h']]],
   ['pn_5ftransport_5ferror',['PN_TRANSPORT_ERROR',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa7c7278de5bcbf3b42b3e692ca21f6c5a',1,'PN_TRANSPORT_ERROR():&#160;event.h'],['../group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa',1,'pn_transport_error(pn_transport_t *transport):&#160;transport.h']]],
@@ -680,10 +691,11 @@ var searchData=
   ['pn_5ftransport_5fget_5ftracer',['pn_transport_get_tracer',['../group__transport.html#ga30d129d04a387ea34515c1641b83521b',1,'transport.h']]],
   ['pn_5ftransport_5fget_5fuser',['pn_transport_get_user',['../group__transport.html#ga6b2750a2d313c65aabe5dc8a99f1de58',1,'transport.h']]],
   ['pn_5ftransport_5fhead',['pn_transport_head',['../group__transport.html#ga3ef8b0032b2a012c697e853e363338ea',1,'transport.h']]],
-  ['pn_5ftransport_5fhead_5fclosed',['PN_TRANSPORT_HEAD_CLOSED',['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51',1,'PN_TRANSPORT_HEAD_CLOSED():&#160;event.h'],['../group__transport.html#ga3eb018b426d168de8c8d9b3441be036c',1,'pn_transport_head_closed(pn_transport_t *transport):&#160;transport.h']]],
+  ['pn_5ftransport_5fhead_5fclosed',['pn_transport_head_closed',['../group__transport.html#ga3eb018b426d168de8c8d9b3441be036c',1,'pn_transport_head_closed(pn_transport_t *transport):&#160;transport.h'],['../group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51',1,'PN_TRANSPORT_HEAD_CLOSED():&#160;event.h']]],
   ['pn_5ftransport_5finput',['pn_transport_input',['../group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d',1,'transport.h']]],
   ['pn_5ftransport_5fis_5fauthenticated',['pn_transport_is_authenticated',['../group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d',1,'transport.h']]],
   ['pn_5ftransport_5fis_5fencrypted',['pn_transport_is_encrypted',['../group__transport.html#ga737021ca419e948932071aad2ad38c5b',1,'transport.h']]],
+  ['pn_5ftransport_5flocal_5faddr',['pn_transport_local_addr',['../group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148',1,'netaddr.h']]],
   ['pn_5ftransport_5flog',['pn_transport_log',['../group__transport.html#gad603e8d72578bcedd2d9235f74f28f37',1,'transport.h']]],
   ['pn_5ftransport_5flogf',['pn_transport_logf',['../group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84',1,'transport.h']]],
   ['pn_5ftransport_5foutput',['pn_transport_output',['../group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e',1,'transport.h']]],
@@ -694,6 +706,7 @@ var searchData=
   ['pn_5ftransport_5fpush',['pn_transport_push',['../group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b',1,'transport.h']]],
   ['pn_5ftransport_5fquiesced',['pn_transport_quiesced',['../group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef',1,'transport.h']]],
   ['pn_5ftransport_5fread_5fclosed',['PN_TRANSPORT_READ_CLOSED',['../group__connection__driver.html#ga9a331416719994f6cb0971acce5208fb',1,'connection_driver.h']]],
+  ['pn_5ftransport_5fremote_5faddr',['pn_transport_remote_addr',['../group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39',1,'netaddr.h']]],
   ['pn_5ftransport_5fremote_5fchannel_5fmax',['pn_transport_remote_channel_max',['../group__transport.html#gaff7c08aeb92596ad9d269468d1557647',1,'transport.h']]],
   ['pn_5ftransport_5frequire_5fauth',['pn_transport_require_auth',['../group__transport.html#ga285b4cced59c665ae178adf26128d3fc',1,'transport.h']]],
   ['pn_5ftransport_5frequire_5fencryption',['pn_transport_require_encryption',['../group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34',1,'transport.h']]],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/functions_0.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/functions_0.js b/content/releases/qpid-proton-master/proton/c/api/search/functions_0.js
index d441d79..ed9116b 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/functions_0.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/functions_0.js
@@ -44,6 +44,7 @@ var searchData=
   ['pn_5fconnection_5fdriver_5flog',['pn_connection_driver_log',['../group__connection__driver.html#gadb682f03cb66b5898c4b285353e0005e',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5flogf',['pn_connection_driver_logf',['../group__connection__driver.html#ga756d1d7130b79f639d71d331f9005cab',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fnext_5fevent',['pn_connection_driver_next_event',['../group__connection__driver.html#ga00b32ae810a25ba6e172d6ed870982a5',1,'connection_driver.h']]],
+  ['pn_5fconnection_5fdriver_5fptr',['pn_connection_driver_ptr',['../group__connection__driver.html#gab9d4f3255c83d7792fc17e5a020ff1c0',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fbuffer',['pn_connection_driver_read_buffer',['../group__connection__driver.html#ga0dd152968de6ec06de352e1cbc51c438',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fclose',['pn_connection_driver_read_close',['../group__connection__driver.html#ga11b59aec2b54acdefd63dfbce8d09a3f',1,'connection_driver.h']]],
   ['pn_5fconnection_5fdriver_5fread_5fclosed',['pn_connection_driver_read_closed',['../group__connection__driver.html#ga56ccde529842f18774fdf827e86afa23',1,'connection_driver.h']]],
@@ -270,7 +271,9 @@ var searchData=
   ['pn_5flink_5ftarget',['pn_link_target',['../group__link.html#ga997c85388b9fb30151ea3b40b946e958',1,'link.h']]],
   ['pn_5flink_5funsettled',['pn_link_unsettled',['../group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1',1,'link.h']]],
   ['pn_5flistener',['pn_listener',['../group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5',1,'listener.h']]],
-  ['pn_5flistener_5faccept',['pn_listener_accept',['../group__listener.html#gaaee3c3f3822484bc2e370406abf5b736',1,'listener.h']]],
+  ['pn_5flistener_5faccept',['pn_listener_accept',['../group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9',1,'listener.h']]],
+  ['pn_5flistener_5faccept2',['pn_listener_accept2',['../group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070',1,'listener.h']]],
+  ['pn_5flistener_5faddr',['pn_listener_addr',['../group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9',1,'netaddr.h']]],
   ['pn_5flistener_5fattachments',['pn_listener_attachments',['../group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f',1,'listener.h']]],
   ['pn_5flistener_5fclose',['pn_listener_close',['../group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104',1,'listener.h']]],
   ['pn_5flistener_5fcondition',['pn_listener_condition',['../group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2',1,'listener.h']]],
@@ -309,6 +312,7 @@ var searchData=
   ['pn_5fmessage_5fis_5ffirst_5facquirer',['pn_message_is_first_acquirer',['../group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2',1,'message.h']]],
   ['pn_5fmessage_5fis_5finferred',['pn_message_is_inferred',['../group__message.html#ga5d9367609d74ca3511d4172806eeb55b',1,'message.h']]],
   ['pn_5fmessage_5fproperties',['pn_message_properties',['../group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad',1,'message.h']]],
+  ['pn_5fmessage_5fsend',['pn_message_send',['../group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5',1,'message.h']]],
   ['pn_5fmessage_5fset_5faddress',['pn_message_set_address',['../group__message.html#ga38ecee233f94e128bed9be3e530f27e5',1,'message.h']]],
   ['pn_5fmessage_5fset_5fcontent_5fencoding',['pn_message_set_content_encoding',['../group__message.html#gafc79b5a0c8bd56aaa07f1357ba07475b',1,'message.h']]],
   ['pn_5fmessage_5fset_5fcontent_5ftype',['pn_message_set_content_type',['../group__message.html#gaa0247560f0cd4590bc8ece20565eb611',1,'message.h']]],
@@ -387,7 +391,10 @@ var searchData=
   ['pn_5fmessenger_5fsubscribe_5fttl',['pn_messenger_subscribe_ttl',['../group__messenger.html#ga480a8623fab904690218c0c67493232f',1,'messenger.h']]],
   ['pn_5fmessenger_5ftracker_5flink',['pn_messenger_tracker_link',['../group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d',1,'messenger.h']]],
   ['pn_5fmessenger_5fwork',['pn_messenger_work',['../group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4',1,'messenger.h']]],
+  ['pn_5fnetaddr_5fhost_5fport',['pn_netaddr_host_port',['../group__proactor.html#ga8cdeab8554e7d376a422dae8ac6d474b',1,'netaddr.h']]],
+  ['pn_5fnetaddr_5flistening',['pn_netaddr_listening',['../group__proactor.html#ga955471a53dd486a6f227d8d57322a44c',1,'netaddr.h']]],
   ['pn_5fnetaddr_5flocal',['pn_netaddr_local',['../group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b',1,'netaddr.h']]],
+  ['pn_5fnetaddr_5fnext',['pn_netaddr_next',['../group__proactor.html#ga6163449ac3b87782628448f192930eb0',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fremote',['pn_netaddr_remote',['../group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fsockaddr',['pn_netaddr_sockaddr',['../group__proactor.html#ga00b1a40af2d837915d21cdb52ccb0c58',1,'netaddr.h']]],
   ['pn_5fnetaddr_5fsocklen',['pn_netaddr_socklen',['../group__proactor.html#gaddaf2b0b3e107d100e4c3658116a6c3c',1,'netaddr.h']]],
@@ -396,6 +403,7 @@ var searchData=
   ['pn_5fproactor_5faddr',['pn_proactor_addr',['../group__proactor.html#gaf67a7642c9003b36255b58776b494c96',1,'proactor.h']]],
   ['pn_5fproactor_5fcancel_5ftimeout',['pn_proactor_cancel_timeout',['../group__proactor.html#gac206e4d0a1b7546d940a83cdd79ce93f',1,'proactor.h']]],
   ['pn_5fproactor_5fconnect',['pn_proactor_connect',['../group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6',1,'proactor.h']]],
+  ['pn_5fproactor_5fconnect2',['pn_proactor_connect2',['../group__proactor.html#gabb093e51449351cf5530bb300bd67ba1',1,'proactor.h']]],
   ['pn_5fproactor_5fdisconnect',['pn_proactor_disconnect',['../group__proactor.html#gac600bd88ed0fc6c2b66bed4a8740bd68',1,'proactor.h']]],
   ['pn_5fproactor_5fdone',['pn_proactor_done',['../group__proactor.html#gade60ff2292b74841766f953b906285c0',1,'proactor.h']]],
   ['pn_5fproactor_5ffree',['pn_proactor_free',['../group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf',1,'proactor.h']]],
@@ -444,8 +452,10 @@ var searchData=
   ['pn_5fssl_5fdomain',['pn_ssl_domain',['../group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fallow_5funsecured_5fclient',['pn_ssl_domain_allow_unsecured_client',['../group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5ffree',['pn_ssl_domain_free',['../group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d',1,'ssl.h']]],
+  ['pn_5fssl_5fdomain_5fset_5fciphers',['pn_ssl_domain_set_ciphers',['../group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5fcredentials',['pn_ssl_domain_set_credentials',['../group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5fpeer_5fauthentication',['pn_ssl_domain_set_peer_authentication',['../group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11',1,'ssl.h']]],
+  ['pn_5fssl_5fdomain_5fset_5fprotocols',['pn_ssl_domain_set_protocols',['../group__ssl.html#ga333fcb941ed20421373f37b23d84fc98',1,'ssl.h']]],
   ['pn_5fssl_5fdomain_5fset_5ftrusted_5fca_5fdb',['pn_ssl_domain_set_trusted_ca_db',['../group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d',1,'ssl.h']]],
   ['pn_5fssl_5fget_5fcert_5ffingerprint',['pn_ssl_get_cert_fingerprint',['../group__ssl.html#ga324db5da83b1abad2e948481d65119d4',1,'ssl.h']]],
   ['pn_5fssl_5fget_5fcipher_5fname',['pn_ssl_get_cipher_name',['../group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52',1,'ssl.h']]],
@@ -506,6 +516,7 @@ var searchData=
   ['pn_5ftransport_5finput',['pn_transport_input',['../group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d',1,'transport.h']]],
   ['pn_5ftransport_5fis_5fauthenticated',['pn_transport_is_authenticated',['../group__transport.html#ga8a60f6a48e4bd2d090f5bd264cf7f90d',1,'transport.h']]],
   ['pn_5ftransport_5fis_5fencrypted',['pn_transport_is_encrypted',['../group__transport.html#ga737021ca419e948932071aad2ad38c5b',1,'transport.h']]],
+  ['pn_5ftransport_5flocal_5faddr',['pn_transport_local_addr',['../group__proactor.html#ga8bcff2f30c1608c1d883eab461cc9148',1,'netaddr.h']]],
   ['pn_5ftransport_5flog',['pn_transport_log',['../group__transport.html#gad603e8d72578bcedd2d9235f74f28f37',1,'transport.h']]],
   ['pn_5ftransport_5flogf',['pn_transport_logf',['../group__transport.html#ga26cff9ffda93e2ffc8606e19eefe7f84',1,'transport.h']]],
   ['pn_5ftransport_5foutput',['pn_transport_output',['../group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e',1,'transport.h']]],
@@ -515,6 +526,7 @@ var searchData=
   ['pn_5ftransport_5fprocess',['pn_transport_process',['../group__transport.html#ga1f52a6f11322873e74b9daf004269a91',1,'transport.h']]],
   ['pn_5ftransport_5fpush',['pn_transport_push',['../group__transport.html#ga50c63f26b8b16f45e6e7912ca54de94b',1,'transport.h']]],
   ['pn_5ftransport_5fquiesced',['pn_transport_quiesced',['../group__transport.html#gab8d9e4729b8835d3740de8d2c78831ef',1,'transport.h']]],
+  ['pn_5ftransport_5fremote_5faddr',['pn_transport_remote_addr',['../group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39',1,'netaddr.h']]],
   ['pn_5ftransport_5fremote_5fchannel_5fmax',['pn_transport_remote_channel_max',['../group__transport.html#gaff7c08aeb92596ad9d269468d1557647',1,'transport.h']]],
   ['pn_5ftransport_5frequire_5fauth',['pn_transport_require_auth',['../group__transport.html#ga285b4cced59c665ae178adf26128d3fc',1,'transport.h']]],
   ['pn_5ftransport_5frequire_5fencryption',['pn_transport_require_encryption',['../group__transport.html#gaeb7e30ead4a6ab080d0005379be20e34',1,'transport.h']]],

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/pages_0.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/pages_0.js b/content/releases/qpid-proton-master/proton/c/api/search/pages_0.js
index 8b446da..038da54 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/pages_0.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/pages_0.js
@@ -1,5 +1,4 @@
 var searchData=
 [
-  ['introduction',['Introduction',['../index.html',1,'']]],
-  ['io_20integration',['IO integration',['../io_page.html',1,'']]]
+  ['deprecated_20list',['Deprecated List',['../deprecated.html',1,'']]]
 ];

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/pages_1.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/pages_1.js b/content/releases/qpid-proton-master/proton/c/api/search/pages_1.js
index 7cf7879..8b446da 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/pages_1.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/pages_1.js
@@ -1,4 +1,5 @@
 var searchData=
 [
-  ['introduction',['Introduction',['../index.html',1,'']]]
+  ['introduction',['Introduction',['../index.html',1,'']]],
+  ['io_20integration',['IO integration',['../io_page.html',1,'']]]
 ];

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/searchdata.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/searchdata.js b/content/releases/qpid-proton-master/proton/c/api/search/searchdata.js
index c17a2d7..47cc4b3 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/searchdata.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/searchdata.js
@@ -9,7 +9,7 @@ var indexSectionsWithContent =
   6: "p",
   7: "p",
   8: "acdeilmpstu",
-  9: "i"
+  9: "di"
 };
 
 var indexSectionNames =

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/selectable_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/selectable_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/selectable_8h_source.html
index 563551a..bdc99e2 100755
--- a/content/releases/qpid-proton-master/proton/c/api/selectable_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/selectable_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/selectable.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,9 +93,9 @@ $(document).ready(function(){initNavTree('selectable_8h_source.html','');});
 <div class="title">selectable.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SELECTABLE_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SELECTABLE_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><
 a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014">
 </a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lin
 eno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a clas
 s="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> pn_iterator_t pn_selectables_t;</div><div class="line"><a name="
 l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#if defined(_WIN32) &amp;&amp; ! defined(__CYGWIN__)</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#ifdef _WIN64</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int64 pn_socket_t;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> <span class="keywordtype">int</span> pn_socket_t;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif</span></d
 iv><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#define PN_INVALID_SOCKET (pn_socket_t)(~0)</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> pn_socket_t;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="preprocessor">#define PN_INVALID_SOCKET (-1)</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_selectable_t pn_selectable_t;<
 /div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNX_EXTERN pn_selectables_t *pn_selectables(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;PNX_EXTERN pn_selectable_t *pn_selectables_next(pn_selectables_t *selectables);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectables_free(pn_selectables_t *selectables);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNX_EXTERN pn_selectable_t *pn_selectable(<span class="keywordty
 pe">void</span>);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_readable(pn_selectable_t *sel, <span class="keywordtype">void</span> (*readable)(pn_selectable_t *));</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_writable(pn_selectable_t *sel, <span class="keywordtype">void</span> (*writable)(pn_selectable_t *));</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_expired(pn_selectable_t *sel, <span class="keywordtype">void</span> (*expired)(pn_selectable_t *));</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectabl
 e_on_error(pn_selectable_t *sel, <span class="keywordtype">void</span> (*error)(pn_selectable_t *));</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_release(pn_selectable_t *sel, <span class="keywordtype">void</span> (*release)(pn_selectable_t *));</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_finalize(pn_selectable_t *sel, <span class="keywordtype">void</span> (*finalize)(pn_selectable_t *));</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PNX_EXTERN pn_record_t *pn_selectable_attachments(pn_selectable_t *sel);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</
 span>&#160;PNX_EXTERN pn_socket_t pn_selectable_get_fd(pn_selectable_t *selectable);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_fd(pn_selectable_t *selectable, pn_socket_t fd);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_reading(pn_selectable_t *selectable);</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_reading(pn_selectable_t *sel, <span class="keywordtype">bool</span> reading);</div><div class="line"><a name="l00149"></a><s
 pan class="lineno">  149</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_writing(pn_selectable_t *selectable);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;  PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_writing(pn_selectable_t *sel, <span class="keywordtype">bool</span> writing);</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_selectable_get_deadline(pn_selectable_t *selectable);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00172
 "></a><span class="lineno">  172</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_deadline(pn_selectable_t *sel, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> deadline);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_readable(pn_selectable_t *selectable);</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_writable(pn_selectable_t *selectable);</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;PNX_EXTERN <span class="keywordtype">
 void</span> pn_selectable_error(pn_selectable_t *selectable);</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_expired(pn_selectable_t *selectable);</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_registered(pn_selectable_t *selectable);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_registered(pn_selectable_t *selectable, <span class="keywordtype">bool</span> registered);</div><div class="line"><a name="l00223"></a><span class="lineno">  2
 23</span>&#160;</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_terminal(pn_selectable_t *selectable);</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_terminate(pn_selectable_t *selectable);</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_release(pn_selectable_t *selectable);</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_free(pn_selectable_t *sel
 ectable);</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_collect(pn_selectable_t *selectable, <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;}</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;<span class="pre
 processor">#endif </span><span class="comment">/* selectable.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:407</div></div>
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SELECTABLE_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SELECTABLE_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><
 a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014">
 </a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lin
 eno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/object.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;<a clas
 s="code" href="event_8h.html">proton/event.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">typedef</span> pn_iterator_t pn_selectables_t;</div><div class="line"><a name="
 l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#if defined(_WIN32) &amp;&amp; ! defined(__CYGWIN__)</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="preprocessor">#ifdef _WIN64</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> __int64 pn_socket_t;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">unsigned</span> <span class="keywordtype">int</span> pn_socket_t;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif</span></d
 iv><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="preprocessor">#define PN_INVALID_SOCKET (pn_socket_t)(~0)</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="keyword">typedef</span> <span class="keywordtype">int</span> pn_socket_t;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="preprocessor">#define PN_INVALID_SOCKET (-1)</span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pn_selectable_t pn_selectable_t;<
 /div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;PNX_EXTERN pn_selectables_t *pn_selectables(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;PNX_EXTERN pn_selectable_t *pn_selectables_next(pn_selectables_t *selectables);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectables_free(pn_selectables_t *selectables);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PNX_EXTERN pn_selectable_t *pn_selectable(<span class="keywordty
 pe">void</span>);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_readable(pn_selectable_t *sel, <span class="keywordtype">void</span> (*readable)(pn_selectable_t *));</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_writable(pn_selectable_t *sel, <span class="keywordtype">void</span> (*writable)(pn_selectable_t *));</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_expired(pn_selectable_t *sel, <span class="keywordtype">void</span> (*expired)(pn_selectable_t *));</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectabl
 e_on_error(pn_selectable_t *sel, <span class="keywordtype">void</span> (*error)(pn_selectable_t *));</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_release(pn_selectable_t *sel, <span class="keywordtype">void</span> (*release)(pn_selectable_t *));</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_on_finalize(pn_selectable_t *sel, <span class="keywordtype">void</span> (*finalize)(pn_selectable_t *));</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PNX_EXTERN pn_record_t *pn_selectable_attachments(pn_selectable_t *sel);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</
 span>&#160;PNX_EXTERN pn_socket_t pn_selectable_get_fd(pn_selectable_t *selectable);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_fd(pn_selectable_t *selectable, pn_socket_t fd);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_reading(pn_selectable_t *selectable);</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_reading(pn_selectable_t *sel, <span class="keywordtype">bool</span> reading);</div><div class="line"><a name="l00149"></a><s
 pan class="lineno">  149</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_writing(pn_selectable_t *selectable);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;  PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_writing(pn_selectable_t *sel, <span class="keywordtype">bool</span> writing);</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> pn_selectable_get_deadline(pn_selectable_t *selectable);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00172
 "></a><span class="lineno">  172</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_deadline(pn_selectable_t *sel, <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> deadline);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_readable(pn_selectable_t *selectable);</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_writable(pn_selectable_t *selectable);</div><div class="line"><a name="l00187"></a><span class="lineno">  187</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;PNX_EXTERN <span class="keywordtype">
 void</span> pn_selectable_error(pn_selectable_t *selectable);</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_expired(pn_selectable_t *selectable);</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_registered(pn_selectable_t *selectable);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_set_registered(pn_selectable_t *selectable, <span class="keywordtype">bool</span> registered);</div><div class="line"><a name="l00223"></a><span class="lineno">  2
 23</span>&#160;</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> pn_selectable_is_terminal(pn_selectable_t *selectable);</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_terminate(pn_selectable_t *selectable);</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_release(pn_selectable_t *selectable);</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_free(pn_selectable_t *sel
 ectable);</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> pn_selectable_collect(pn_selectable_t *selectable, <a class="code" href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a> *collector);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;}</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;<span class="pre
 processor">#endif </span><span class="comment">/* selectable.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__event_html_ga905cdecedb8020bc28e648e43348b5d1"><div class="ttname"><a href="group__event.html#ga905cdecedb8020bc28e648e43348b5d1">pn_collector_t</a></div><div class="ttdeci">struct pn_collector_t pn_collector_t</div><div class="ttdoc">An event collector. </div><div class="ttdef"><b>Definition:</b> types.h:413</div></div>
 <div class="ttc" id="event_8h_html"><div class="ttname"><a href="event_8h.html">event.h</a></div><div class="ttdoc">Protocol and transport events. </div></div>
-<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:160</div></div>
+<div class="ttc" id="group__amqp__types_html_gad337c365b498106064ec28e00e5fb6dd"><div class="ttname"><a href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a></div><div class="ttdeci">int64_t pn_timestamp_t</div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> types.h:166</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
@@ -104,7 +104,7 @@ $(document).ready(function(){initNavTree('selectable_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>selectable.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>


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


[36/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/messenger_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/messenger_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/messenger_8h_source.html
index 2f686fc..e1d5d4e 100755
--- a/content/releases/qpid-proton-master/proton/c/api/messenger_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/messenger_8h_source.html
@@ -93,11 +93,11 @@ $(document).ready(function(){initNavTree('messenger_8h_source.html','');});
 <div class="title">messenger.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="messenger_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSENGER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSENGER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor licen
 se agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span
  class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the<
 /span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="message_8h.html">proton/message.h</a>&gt;</span></div><div class="li
 ne"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;proton/selectable.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="ssl_8h.html">proton/ssl.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33
 </span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno"><a class="line" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">  156</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> <a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a>;</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno"><a class="line" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">  165</a></span>&#160
 ;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno"><a class="line" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">  171</a></span>&#160;<span class="keyword">typedef</span> int64_t <a class="code" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">pn_tracker_t</a>;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00177"></a><span class="lineno"><a class="line" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">  177</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {<
 /div><div class="line"><a name="l00178"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2">  178</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2">PN_STATUS_UNKNOWN</a> = 0, </div><div class="line"><a name="l00179"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611">  179</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611">PN_STATUS_PENDING</a> = 1, </div><div class="line"><a name="l00182"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467">  182</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04
 a4bf1467">PN_STATUS_ACCEPTED</a> = 2, </div><div class="line"><a name="l00183"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf">  183</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf">PN_STATUS_REJECTED</a> = 3, </div><div class="line"><a name="l00184"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852">  184</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852">PN_STATUS_RELEASED</a> = 4, </div><div class="line"><a name="l00185"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8">  185</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a41
 6443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8">PN_STATUS_MODIFIED</a> = 5, </div><div class="line"><a name="l00186"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee">  186</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee">PN_STATUS_ABORTED</a> = 6, </div><div class="line"><a name="l00187"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583">  187</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583">PN_STATUS_SETTLED</a> = 7 </div><div class="line"><a name="l00188"></a><span class="lineno">  188</span>&#160;} <a class="code" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">pn_status_t</a>;</div><div class="line"><a name="l00189"></a><s
 pan class="lineno">  189</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *<a class="code" href="group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433">pn_messenger</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga71197163a69770575df74e3cee617429">pn_messenger_name</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;</div><div class="line"><a name="l0021
 8"></a><span class="lineno">  218</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad61fff52c28501171ecbb0b21bbde954">pn_messenger_set_certificate</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *certificate);</div><div class="line"><a name="l00219"></a><span class="lineno">  219</span>&#160;</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b">pn_messenger_get_certificate</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="line"><a name
 ="l00237"></a><span class="lineno">  237</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958">pn_messenger_set_private_key</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *private_key);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1">pn_messenger_get_private_key</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;</div><div class="line">
 <a name="l00255"></a><span class="lineno">  255</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2">pn_messenger_set_password</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00256"></a><span class="lineno">  256</span>&#160;</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a">pn_messenger_get_password</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00264"></a><span class="lineno">  264</span>&#160;</div><div class="line"><a
  name="l00276"></a><span class="lineno">  276</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b">pn_messenger_set_trusted_certificates</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *cert_db);</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2">pn_messenger_get_trusted_certificates</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div
 ><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74">pn_messenger_set_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> timeout);</div><div class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb">pn_messenger_get_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00309"></a><span class="lineno">  309</span>&#160;</div><div class="line"><a name="l00316"></a><span class="lineno">  316</span>&#160;
 PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#gaf572cbf224105d08898d2906336712f7">pn_messenger_is_blocking</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00317"></a><span class="lineno">  317</span>&#160;</div><div class="line"><a name="l00326"></a><span class="lineno">  326</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981">pn_messenger_set_blocking</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">bool</span> blocking);</div><div class="line"><a name="l00327"></a><span class="lineno">  327</span>&#160;</div><div class="line"><a name="l00340"></a><span class="lineno">  340</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="grou
 p__messenger.html#ga63805c35f18ef041c69a14564dc1bce4">pn_messenger_is_passive</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00341"></a><span class="lineno">  341</span>&#160;</div><div class="line"><a name="l00352"></a><span class="lineno">  352</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0">pn_messenger_set_passive</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">bool</span> passive);</div><div class="line"><a name="l00353"></a><span class="lineno">  353</span>&#160;</div><div class="line"><a name="l00359"></a><span class="lineno">  359</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga530295575eda95e3c19316d41bd1baa7">pn_messenger_free</a>(<a
  class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00360"></a><span class="lineno">  360</span>&#160;</div><div class="line"><a name="l00374"></a><span class="lineno">  374</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c">pn_messenger_errno</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00375"></a><span class="lineno">  375</span>&#160;</div><div class="line"><a name="l00387"></a><span class="lineno">  387</span>&#160;PNX_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2">pn_messenger_error</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_m
 essenger_t</a> *messenger);</div><div class="line"><a name="l00388"></a><span class="lineno">  388</span>&#160;</div><div class="line"><a name="l00404"></a><span class="lineno">  404</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1">pn_messenger_get_outgoing_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00405"></a><span class="lineno">  405</span>&#160;</div><div class="line"><a name="l00416"></a><span class="lineno">  416</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc">pn_messenger_set_outgoing_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> window);</div><div class="line"><a name="l004
 17"></a><span class="lineno">  417</span>&#160;</div><div class="line"><a name="l00436"></a><span class="lineno">  436</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga45d578f39673ad59ca65d2042054abee">pn_messenger_get_incoming_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00437"></a><span class="lineno">  437</span>&#160;</div><div class="line"><a name="l00448"></a><span class="lineno">  448</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3">pn_messenger_set_incoming_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00449"></a><span class="lineno">  449</span>&#160;                                               <span class="key
 wordtype">int</span> window);</div><div class="line"><a name="l00450"></a><span class="lineno">  450</span>&#160;</div><div class="line"><a name="l00459"></a><span class="lineno">  459</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6fa594235e316cd2a04b44b283194a43">pn_messenger_start</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00460"></a><span class="lineno">  460</span>&#160;</div><div class="line"><a name="l00475"></a><span class="lineno">  475</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c">pn_messenger_stop</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00476"></a><span class="lineno">  476</span>&#160;</div><div class="line"><
 a name="l00484"></a><span class="lineno">  484</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4">pn_messenger_stopped</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00485"></a><span class="lineno">  485</span>&#160;</div><div class="line"><a name="l00493"></a><span class="lineno">  493</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *<a class="code" href="group__messenger.html#gac36589fe5dc0378cf62558e40060a26f">pn_messenger_subscribe</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *source);</div><div class="line"><a name="l00494"></a><span class="lineno">  494</span>&#160;</div><
 div class="line"><a name="l00505"></a><span class="lineno">  505</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *</div><div class="line"><a name="l00506"></a><span class="lineno">  506</span>&#160;<a class="code" href="group__messenger.html#ga480a8623fab904690218c0c67493232f">pn_messenger_subscribe_ttl</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *source,</div><div class="line"><a name="l00507"></a><span class="lineno">  507</span>&#160;                           <a class="code" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a> timeout);</div><div class="line"><a name="l00508"></a><span class="lineno">  508</span>&#160;</div><div class="line"><a name="l00518"></a><span class="lineno">  518</span>&#160;PNX_EXTERN <a class="code" href="
 group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__messenger.html#ga757aeef23d47ecc2a9a461b882686417">pn_messenger_get_link</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00519"></a><span class="lineno">  519</span>&#160;                                           <span class="keyword">const</span> <span class="keywordtype">char</span> *address, <span class="keywordtype">bool</span> sender);</div><div class="line"><a name="l00520"></a><span class="lineno">  520</span>&#160;</div><div class="line"><a name="l00529"></a><span class="lineno">  529</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787">pn_subscription_get_context</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub);</div><div class="l
 ine"><a name="l00530"></a><span class="lineno">  530</span>&#160;</div><div class="line"><a name="l00537"></a><span class="lineno">  537</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10">pn_subscription_set_context</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00538"></a><span class="lineno">  538</span>&#160;</div><div class="line"><a name="l00545"></a><span class="lineno">  545</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e">pn_subscription_address</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub);</div><div class="line"><a name="l00546"></a><span class="line
 no">  546</span>&#160;</div><div class="line"><a name="l00557"></a><span class="lineno">  557</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a">pn_messenger_put</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00558"></a><span class="lineno">  558</span>&#160;</div><div class="line"><a name="l00570"></a><span class="lineno">  570</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">pn_status_t</a> <a class="code" href="group__messenger.html#gad398544ad1374f67c922115ae1cceacc">pn_messenger_status</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker);</div><div class="
 line"><a name="l00571"></a><span class="lineno">  571</span>&#160;</div><div class="line"><a name="l00583"></a><span class="lineno">  583</span>&#160;PNX_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0">pn_messenger_delivery</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00584"></a><span class="lineno">  584</span>&#160;                                               pn_tracker_t tracker);</div><div class="line"><a name="l00585"></a><span class="lineno">  585</span>&#160;</div><div class="line"><a name="l00598"></a><span class="lineno">  598</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6">pn_messenger_buffered</a>(<a class="code" href="group__messenger.html#ga
 0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker);</div><div class="line"><a name="l00599"></a><span class="lineno">  599</span>&#160;</div><div class="line"><a name="l00612"></a><span class="lineno">  612</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d">pn_messenger_settle</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00613"></a><span class="lineno">  613</span>&#160;</div><div class="line"><a name="l00627"></a><span class="lineno">  627</span>&#160;PNX_EXTERN pn_tracker_t <a class="code" href="group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1">pn_messenger_outgoing_tracker</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messeng
 er);</div><div class="line"><a name="l00628"></a><span class="lineno">  628</span>&#160;</div><div class="line"><a name="l00639"></a><span class="lineno">  639</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4">pn_messenger_work</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> timeout);</div><div class="line"><a name="l00640"></a><span class="lineno">  640</span>&#160;</div><div class="line"><a name="l00652"></a><span class="lineno">  652</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f">pn_messenger_interrupt</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00653"></a><span class="lineno">  653</span>&#160;
 </div><div class="line"><a name="l00686"></a><span class="lineno">  686</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae31f9a99dcbedffe83588cf25b805325">pn_messenger_send</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> n);</div><div class="line"><a name="l00687"></a><span class="lineno">  687</span>&#160;</div><div class="line"><a name="l00712"></a><span class="lineno">  712</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6">pn_messenger_recv</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> limit);</div><div class="line"><a name="l00713"></a><span class="lineno">  713</span>&#160;</div><div class="line"><a name="l00724"></a><span clas
 s="lineno">  724</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5">pn_messenger_receiving</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00725"></a><span class="lineno">  725</span>&#160;</div><div class="line"><a name="l00740"></a><span class="lineno">  740</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540">pn_messenger_get</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *message);</div><div class="line"><a name="l00741"></a><span class="lineno">  741</span>&#160;</div><div class="line"><a name="l00755"></a><span class="lineno">  755</span>&#160;P
 NX_EXTERN pn_tracker_t <a class="code" href="group__messenger.html#gafe31e771826f8107d93fc276c9715aab">pn_messenger_incoming_tracker</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00756"></a><span class="lineno">  756</span>&#160;</div><div class="line"><a name="l00766"></a><span class="lineno">  766</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *<a class="code" href="group__messenger.html#gae351d031d2ef29bdb137a59d461c4253">pn_messenger_incoming_subscription</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00767"></a><span class="lineno">  767</span>&#160;</div><div class="line"><a name="l00771"></a><span class="lineno"><a class="line" href="group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9">  771</
 a></span>&#160;<span class="preprocessor">#define PN_CUMULATIVE (0x1)</span></div><div class="line"><a name="l00772"></a><span class="lineno">  772</span>&#160;</div><div class="line"><a name="l00794"></a><span class="lineno">  794</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7">pn_messenger_accept</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00795"></a><span class="lineno">  795</span>&#160;</div><div class="line"><a name="l00817"></a><span class="lineno">  817</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c">pn_messenger_reject</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *mess
 enger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00818"></a><span class="lineno">  818</span>&#160;</div><div class="line"><a name="l00826"></a><span class="lineno">  826</span>&#160;PNX_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d">pn_messenger_tracker_link</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00827"></a><span class="lineno">  827</span>&#160;                                               pn_tracker_t tracker);</div><div class="line"><a name="l00828"></a><span class="lineno">  828</span>&#160;</div><div class="line"><a name="l00836"></a><span class="lineno">  836</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga06c3a066422f8a966523
 b43a61f62eb9">pn_messenger_outgoing</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00837"></a><span class="lineno">  837</span>&#160;</div><div class="line"><a name="l00844"></a><span class="lineno">  844</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257">pn_messenger_incoming</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00845"></a><span class="lineno">  845</span>&#160;</div><div class="line"><a name="l00908"></a><span class="lineno">  908</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e">pn_messenger_route</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t
 </a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *pattern,</div><div class="line"><a name="l00909"></a><span class="lineno">  909</span>&#160;                                 <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l00910"></a><span class="lineno">  910</span>&#160;</div><div class="line"><a name="l00933"></a><span class="lineno">  933</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff">pn_messenger_rewrite</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *pattern,</div><div class="line"><a name="l00934"></a><span class="lineno">  934</span>&#160;                                   <span class="keyword">const</span> <span class="keywordtype">char
 </span> *address);</div><div class="line"><a name="l00935"></a><span class="lineno">  935</span>&#160;</div><div class="line"><a name="l00962"></a><span class="lineno">  962</span>&#160;PNX_EXTERN pn_selectable_t *<a class="code" href="group__messenger.html#ga8521b0999200c076bf12568ac10fe925">pn_messenger_selectable</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00963"></a><span class="lineno">  963</span>&#160;</div><div class="line"><a name="l00970"></a><span class="lineno">  970</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b">pn_messenger_deadline</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00971"></a><span class="lineno"> 
  971</span>&#160;</div><div class="line"><a name="l00972"></a><span class="lineno"><a class="line" href="group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14">  972</a></span>&#160;<span class="preprocessor">#define PN_FLAGS_CHECK_ROUTES                                                   \</span></div><div class="line"><a name="l00973"></a><span class="lineno">  973</span>&#160;<span class="preprocessor">  (0x1) </span></div><div class="line"><a name="l00977"></a><span class="lineno">  977</span>&#160;<span class="preprocessor">#define PN_FLAGS_ALLOW_INSECURE_MECHS                                           \</span></div><div class="line"><a name="l00978"></a><span class="lineno">  978</span>&#160;<span class="preprocessor">  (0x2) </span></div><div class="line"><a name="l00990"></a><span class="lineno">  990</span>&#160;<span class="preprocessor">PNX_EXTERN int pn_messenger_set_flags(pn_messenger_t *messenger,</span></div><div class="line"><a name="l00991"></a><span class="lineno
 ">  991</span>&#160;                                     <span class="keyword">const</span> <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00992"></a><span class="lineno">  992</span>&#160;</div><div class="line"><a name="l00999"></a><span class="lineno">  999</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085">pn_messenger_get_flags</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l01000"></a><span class="lineno"> 1000</span>&#160;</div><div class="line"><a name="l01007"></a><span class="lineno"> 1007</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e">pn_messenger_set_snd_settle_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t
 </a> *messenger,</div><div class="line"><a name="l01008"></a><span class="lineno"> 1008</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> mode);</div><div class="line"><a name="l01009"></a><span class="lineno"> 1009</span>&#160;</div><div class="line"><a name="l01016"></a><span class="lineno"> 1016</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1">pn_messenger_set_rcv_settle_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01017"></a><span class="lineno"> 1017</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> 
 mode);</div><div class="line"><a name="l01018"></a><span class="lineno"> 1018</span>&#160;</div><div class="line"><a name="l01025"></a><span class="lineno"> 1025</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6">pn_messenger_set_tracer</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01026"></a><span class="lineno"> 1026</span>&#160;                                       <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> tracer);</div><div class="line"><a name="l01027"></a><span class="lineno"> 1027</span>&#160;</div><div class="line"><a name="l01035"></a><span class="lineno"> 1035</span>&#160;PNX_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="line"><a name="l01036"></a><span cla
 ss="lineno"> 1036</span>&#160;    <a class="code" href="group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7">pn_messenger_get_remote_idle_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01037"></a><span class="lineno"> 1037</span>&#160;                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l01038"></a><span class="lineno"> 1038</span>&#160;</div><div class="line"><a name="l01048"></a><span class="lineno"> 1048</span>&#160;PNX_EXTERN <span class="keywordtype">int</span></div><div class="line"><a name="l01049"></a><span class="lineno"> 1049</span>&#160;<a class="code" href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">pn_messenger_set_ssl_peer_authentication_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t<
 /a> *messenger,</div><div class="line"><a name="l01050"></a><span class="lineno"> 1050</span>&#160;                                              <span class="keyword">const</span> <a class="code" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode);</div><div class="line"><a name="l01051"></a><span class="lineno"> 1051</span>&#160;</div><div class="line"><a name="l01056"></a><span class="lineno"> 1056</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l01057"></a><span class="lineno"> 1057</span>&#160;}</div><div class="line"><a name="l01058"></a><span class="lineno"> 1058</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l01059"></a><span class="lineno"> 1059</span>&#160;</div><div class="line"><a name="l01060"></a><span class="lineno"> 1060</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* messenger.h */</span><span class="preprocessor"><
 /span></div><div class="ttc" id="group__messenger_html_ga083ba6296a1ae1dfe45c0fb82da823eb"><div class="ttname"><a href="group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb">pn_messenger_get_timeout</a></div><div class="ttdeci">int pn_messenger_get_timeout(pn_messenger_t *messenger)</div><div class="ttdoc">Gets the timeout for a messenger object. </div></div>
+<a href="messenger_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSENGER_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSENGER_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor licen
 se agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span
  class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the<
 /span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="message_8h.html">proton/message.h</a>&gt;</span></div><div class="li
 ne"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;proton/selectable.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="link_8h.html">proton/link.h</a>&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="ssl_8h.html">proton/ssl.h</a>&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33
 </span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00154"></a><span class="lineno"><a class="line" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">  154</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> <a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a>;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno"><a class="line" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">  159</a></span>&#160
 ;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno"><a class="line" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">  165</a></span>&#160;<span class="keyword">typedef</span> int64_t <a class="code" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">pn_tracker_t</a>;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno"><a class="line" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">  171</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {<
 /div><div class="line"><a name="l00172"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2">  172</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba0b46b1041679460baaba2ddcdb2173f2">PN_STATUS_UNKNOWN</a> = 0, </div><div class="line"><a name="l00173"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611">  173</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba4b0354a77173cd75c69159e15c23f611">PN_STATUS_PENDING</a> = 1, </div><div class="line"><a name="l00176"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04a4bf1467">  176</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba693fd9044a50a4f02e842d04
 a4bf1467">PN_STATUS_ACCEPTED</a> = 2, </div><div class="line"><a name="l00177"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf">  177</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045baf109df703952744009b3547f3b8f32bf">PN_STATUS_REJECTED</a> = 3, </div><div class="line"><a name="l00178"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852">  178</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba67079750477effb7935df83381c47852">PN_STATUS_RELEASED</a> = 4, </div><div class="line"><a name="l00179"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8">  179</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a41
 6443c7da5f6e045ba77d94a6b6b745eef9307f144b57e81e8">PN_STATUS_MODIFIED</a> = 5, </div><div class="line"><a name="l00180"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee">  180</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1239e8ada7eabe2aeab98f2c881cd2ee">PN_STATUS_ABORTED</a> = 6, </div><div class="line"><a name="l00181"></a><span class="lineno"><a class="line" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583">  181</a></span>&#160;  <a class="code" href="group__messenger.html#gga242e4ee54b9c0a416443c7da5f6e045ba1181bc7f51502ae11ed240866cd64583">PN_STATUS_SETTLED</a> = 7 </div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;} <a class="code" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">pn_status_t</a>;</div><div class="line"><a name="l00183"></a><s
 pan class="lineno">  183</span>&#160;</div><div class="line"><a name="l00193"></a><span class="lineno">  193</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *<a class="code" href="group__messenger.html#gabe045d16ca8eb1e3cc87387e2ae82433">pn_messenger</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga71197163a69770575df74e3cee617429">pn_messenger_name</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l0021
 2"></a><span class="lineno">  212</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad61fff52c28501171ecbb0b21bbde954">pn_messenger_set_certificate</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *certificate);</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga1d0c003a1fb5e20b894e2deb8b43118b">pn_messenger_get_certificate</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;</div><div class="line"><a name
 ="l00231"></a><span class="lineno">  231</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga05f059a2fe93e0acbcf76e494e6bf958">pn_messenger_set_private_key</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *private_key);</div><div class="line"><a name="l00232"></a><span class="lineno">  232</span>&#160;</div><div class="line"><a name="l00239"></a><span class="lineno">  239</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#gab692f989aed2aa83bd71b7fa7196aeb1">pn_messenger_get_private_key</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00240"></a><span class="lineno">  240</span>&#160;</div><div class="line">
 <a name="l00249"></a><span class="lineno">  249</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6b04f7dea2ed8752b8672b4cfe0330f2">pn_messenger_set_password</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga3f02ad7340a59c5982e6223aaeea803a">pn_messenger_get_password</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00258"></a><span class="lineno">  258</span>&#160;</div><div class="line"><a
  name="l00270"></a><span class="lineno">  270</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad901e92e2bee6d5371dcd3b1c8fe2c3b">pn_messenger_set_trusted_certificates</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *cert_db);</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga955b218a8f58560e9e228ca14fba21f2">pn_messenger_get_trusted_certificates</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;</div
 ><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga04119bb2b16bb0f657f1dbcf73827d74">pn_messenger_set_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> timeout);</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;</div><div class="line"><a name="l00302"></a><span class="lineno">  302</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb">pn_messenger_get_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00303"></a><span class="lineno">  303</span>&#160;</div><div class="line"><a name="l00310"></a><span class="lineno">  310</span>&#160;
 PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#gaf572cbf224105d08898d2906336712f7">pn_messenger_is_blocking</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00311"></a><span class="lineno">  311</span>&#160;</div><div class="line"><a name="l00320"></a><span class="lineno">  320</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae9d7f1aec6e2cf3ef1ee326a4ae15981">pn_messenger_set_blocking</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">bool</span> blocking);</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;</div><div class="line"><a name="l00334"></a><span class="lineno">  334</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="grou
 p__messenger.html#ga63805c35f18ef041c69a14564dc1bce4">pn_messenger_is_passive</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00335"></a><span class="lineno">  335</span>&#160;</div><div class="line"><a name="l00346"></a><span class="lineno">  346</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac7df7c92396f10f105ec74d35310a7c0">pn_messenger_set_passive</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">bool</span> passive);</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;</div><div class="line"><a name="l00353"></a><span class="lineno">  353</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga530295575eda95e3c19316d41bd1baa7">pn_messenger_free</a>(<a
  class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00354"></a><span class="lineno">  354</span>&#160;</div><div class="line"><a name="l00368"></a><span class="lineno">  368</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gacfd10311abca28521fe7aa9cabfff61c">pn_messenger_errno</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00369"></a><span class="lineno">  369</span>&#160;</div><div class="line"><a name="l00381"></a><span class="lineno">  381</span>&#160;PNX_EXTERN <a class="code" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *<a class="code" href="group__messenger.html#ga0301664be9c54b3a573578776ad2a5d2">pn_messenger_error</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_m
 essenger_t</a> *messenger);</div><div class="line"><a name="l00382"></a><span class="lineno">  382</span>&#160;</div><div class="line"><a name="l00398"></a><span class="lineno">  398</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac191bdb410b7839d6306a0d8e5ac19e1">pn_messenger_get_outgoing_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00399"></a><span class="lineno">  399</span>&#160;</div><div class="line"><a name="l00410"></a><span class="lineno">  410</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga96487581bd8348f8bc9bacef25042cfc">pn_messenger_set_outgoing_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> window);</div><div class="line"><a name="l004
 11"></a><span class="lineno">  411</span>&#160;</div><div class="line"><a name="l00430"></a><span class="lineno">  430</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga45d578f39673ad59ca65d2042054abee">pn_messenger_get_incoming_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00431"></a><span class="lineno">  431</span>&#160;</div><div class="line"><a name="l00442"></a><span class="lineno">  442</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gadf8a9cf14bf8d519026ea8c4eeb275c3">pn_messenger_set_incoming_window</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00443"></a><span class="lineno">  443</span>&#160;                                               <span class="key
 wordtype">int</span> window);</div><div class="line"><a name="l00444"></a><span class="lineno">  444</span>&#160;</div><div class="line"><a name="l00453"></a><span class="lineno">  453</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6fa594235e316cd2a04b44b283194a43">pn_messenger_start</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00454"></a><span class="lineno">  454</span>&#160;</div><div class="line"><a name="l00469"></a><span class="lineno">  469</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gad95ab6daf6b2a61b79d5128a7d1d9f5c">pn_messenger_stop</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00470"></a><span class="lineno">  470</span>&#160;</div><div class="line"><
 a name="l00478"></a><span class="lineno">  478</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#gae2c4765839c8fd09c0e01d05a118b6d4">pn_messenger_stopped</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00479"></a><span class="lineno">  479</span>&#160;</div><div class="line"><a name="l00487"></a><span class="lineno">  487</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *<a class="code" href="group__messenger.html#gac36589fe5dc0378cf62558e40060a26f">pn_messenger_subscribe</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *source);</div><div class="line"><a name="l00488"></a><span class="lineno">  488</span>&#160;</div><
 div class="line"><a name="l00499"></a><span class="lineno">  499</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *</div><div class="line"><a name="l00500"></a><span class="lineno">  500</span>&#160;<a class="code" href="group__messenger.html#ga480a8623fab904690218c0c67493232f">pn_messenger_subscribe_ttl</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *source,</div><div class="line"><a name="l00501"></a><span class="lineno">  501</span>&#160;                           <a class="code" href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a> timeout);</div><div class="line"><a name="l00502"></a><span class="lineno">  502</span>&#160;</div><div class="line"><a name="l00512"></a><span class="lineno">  512</span>&#160;PNX_EXTERN <a class="code" href="
 group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__messenger.html#ga757aeef23d47ecc2a9a461b882686417">pn_messenger_get_link</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00513"></a><span class="lineno">  513</span>&#160;                                           <span class="keyword">const</span> <span class="keywordtype">char</span> *address, <span class="keywordtype">bool</span> sender);</div><div class="line"><a name="l00514"></a><span class="lineno">  514</span>&#160;</div><div class="line"><a name="l00523"></a><span class="lineno">  523</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__messenger.html#ga8ad0f0db6d7cfe0e95d44d433843d787">pn_subscription_get_context</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub);</div><div class="l
 ine"><a name="l00524"></a><span class="lineno">  524</span>&#160;</div><div class="line"><a name="l00531"></a><span class="lineno">  531</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga3a7f95a2a86f64babe692d21ffe9cd10">pn_subscription_set_context</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00532"></a><span class="lineno">  532</span>&#160;</div><div class="line"><a name="l00539"></a><span class="lineno">  539</span>&#160;PNX_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__messenger.html#ga8e87c040776f1941f21d2c15f24b835e">pn_subscription_address</a>(<a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *sub);</div><div class="line"><a name="l00540"></a><span class="line
 no">  540</span>&#160;</div><div class="line"><a name="l00551"></a><span class="lineno">  551</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gafede68af29484d50d531cc48ab0d3d4a">pn_messenger_put</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *msg);</div><div class="line"><a name="l00552"></a><span class="lineno">  552</span>&#160;</div><div class="line"><a name="l00564"></a><span class="lineno">  564</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#ga242e4ee54b9c0a416443c7da5f6e045b">pn_status_t</a> <a class="code" href="group__messenger.html#gad398544ad1374f67c922115ae1cceacc">pn_messenger_status</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker);</div><div class="
 line"><a name="l00565"></a><span class="lineno">  565</span>&#160;</div><div class="line"><a name="l00577"></a><span class="lineno">  577</span>&#160;PNX_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__messenger.html#ga65f22122f08bc93de2bfe155aa12d0b0">pn_messenger_delivery</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00578"></a><span class="lineno">  578</span>&#160;                                               pn_tracker_t tracker);</div><div class="line"><a name="l00579"></a><span class="lineno">  579</span>&#160;</div><div class="line"><a name="l00592"></a><span class="lineno">  592</span>&#160;PNX_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__messenger.html#ga15adeb707f15b86df1e5486c34a060e6">pn_messenger_buffered</a>(<a class="code" href="group__messenger.html#ga
 0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker);</div><div class="line"><a name="l00593"></a><span class="lineno">  593</span>&#160;</div><div class="line"><a name="l00606"></a><span class="lineno">  606</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga475ce593f6b0c6025516ae48360dee4d">pn_messenger_settle</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00607"></a><span class="lineno">  607</span>&#160;</div><div class="line"><a name="l00621"></a><span class="lineno">  621</span>&#160;PNX_EXTERN pn_tracker_t <a class="code" href="group__messenger.html#ga0212b5cfe07a7f758ec472d67d0f56e1">pn_messenger_outgoing_tracker</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messeng
 er);</div><div class="line"><a name="l00622"></a><span class="lineno">  622</span>&#160;</div><div class="line"><a name="l00633"></a><span class="lineno">  633</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga47d60cec6a55e0675b8f073067eff9c4">pn_messenger_work</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> timeout);</div><div class="line"><a name="l00634"></a><span class="lineno">  634</span>&#160;</div><div class="line"><a name="l00646"></a><span class="lineno">  646</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga9da14c67acc17bc5fec6f34e2749534f">pn_messenger_interrupt</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00647"></a><span class="lineno">  647</span>&#160;
 </div><div class="line"><a name="l00680"></a><span class="lineno">  680</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae31f9a99dcbedffe83588cf25b805325">pn_messenger_send</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> n);</div><div class="line"><a name="l00681"></a><span class="lineno">  681</span>&#160;</div><div class="line"><a name="l00706"></a><span class="lineno">  706</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga16c945185e4eb5dcb9aac2be2fcab0d6">pn_messenger_recv</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keywordtype">int</span> limit);</div><div class="line"><a name="l00707"></a><span class="lineno">  707</span>&#160;</div><div class="line"><a name="l00718"></a><span clas
 s="lineno">  718</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gaf4e22c8cb1436891d42ca0a658fca9c5">pn_messenger_receiving</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00719"></a><span class="lineno">  719</span>&#160;</div><div class="line"><a name="l00734"></a><span class="lineno">  734</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gaa6d85929e4b4b574690927ddde00c540">pn_messenger_get</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <a class="code" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2">pn_message_t</a> *message);</div><div class="line"><a name="l00735"></a><span class="lineno">  735</span>&#160;</div><div class="line"><a name="l00749"></a><span class="lineno">  749</span>&#160;P
 NX_EXTERN pn_tracker_t <a class="code" href="group__messenger.html#gafe31e771826f8107d93fc276c9715aab">pn_messenger_incoming_tracker</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00750"></a><span class="lineno">  750</span>&#160;</div><div class="line"><a name="l00760"></a><span class="lineno">  760</span>&#160;PNX_EXTERN <a class="code" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a> *<a class="code" href="group__messenger.html#gae351d031d2ef29bdb137a59d461c4253">pn_messenger_incoming_subscription</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00761"></a><span class="lineno">  761</span>&#160;</div><div class="line"><a name="l00765"></a><span class="lineno"><a class="line" href="group__messenger.html#ga6c2e8d006ec05b913fa1e6dc510d23b9">  765</
 a></span>&#160;<span class="preprocessor">#define PN_CUMULATIVE (0x1)</span></div><div class="line"><a name="l00766"></a><span class="lineno">  766</span>&#160;</div><div class="line"><a name="l00788"></a><span class="lineno">  788</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga11cd0d3423482e1ddda7a8b0cbb581c7">pn_messenger_accept</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00789"></a><span class="lineno">  789</span>&#160;</div><div class="line"><a name="l00811"></a><span class="lineno">  811</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga22d6de108fa967a43ab2473d6a915e9c">pn_messenger_reject</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *mess
 enger, pn_tracker_t tracker, <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00812"></a><span class="lineno">  812</span>&#160;</div><div class="line"><a name="l00820"></a><span class="lineno">  820</span>&#160;PNX_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__messenger.html#gae4e5e89c6ea2a820a221af61cc741c7d">pn_messenger_tracker_link</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l00821"></a><span class="lineno">  821</span>&#160;                                               pn_tracker_t tracker);</div><div class="line"><a name="l00822"></a><span class="lineno">  822</span>&#160;</div><div class="line"><a name="l00830"></a><span class="lineno">  830</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga06c3a066422f8a966523
 b43a61f62eb9">pn_messenger_outgoing</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00831"></a><span class="lineno">  831</span>&#160;</div><div class="line"><a name="l00838"></a><span class="lineno">  838</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga43cf91b5528c2729b3ff9ae1d2a7d257">pn_messenger_incoming</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00839"></a><span class="lineno">  839</span>&#160;</div><div class="line"><a name="l00902"></a><span class="lineno">  902</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga6c85a08d72ae73a18f9fb64ccf0c470e">pn_messenger_route</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t
 </a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *pattern,</div><div class="line"><a name="l00903"></a><span class="lineno">  903</span>&#160;                                 <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l00904"></a><span class="lineno">  904</span>&#160;</div><div class="line"><a name="l00927"></a><span class="lineno">  927</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gac7dc5d9b82f9e015fd2c7d9743099eff">pn_messenger_rewrite</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, <span class="keyword">const</span> <span class="keywordtype">char</span> *pattern,</div><div class="line"><a name="l00928"></a><span class="lineno">  928</span>&#160;                                   <span class="keyword">const</span> <span class="keywordtype">char
 </span> *address);</div><div class="line"><a name="l00929"></a><span class="lineno">  929</span>&#160;</div><div class="line"><a name="l00956"></a><span class="lineno">  956</span>&#160;PNX_EXTERN pn_selectable_t *<a class="code" href="group__messenger.html#ga8521b0999200c076bf12568ac10fe925">pn_messenger_selectable</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00957"></a><span class="lineno">  957</span>&#160;</div><div class="line"><a name="l00964"></a><span class="lineno">  964</span>&#160;PNX_EXTERN <a class="code" href="group__amqp__types.html#gad337c365b498106064ec28e00e5fb6dd">pn_timestamp_t</a> <a class="code" href="group__messenger.html#ga223e7c16f3e84f4e573864c3881b3b4b">pn_messenger_deadline</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00965"></a><span class="lineno"> 
  965</span>&#160;</div><div class="line"><a name="l00966"></a><span class="lineno"><a class="line" href="group__messenger.html#gad5ad0b67fef0e761dc0138b9621ffa14">  966</a></span>&#160;<span class="preprocessor">#define PN_FLAGS_CHECK_ROUTES                                                   \</span></div><div class="line"><a name="l00967"></a><span class="lineno">  967</span>&#160;<span class="preprocessor">  (0x1) </span></div><div class="line"><a name="l00971"></a><span class="lineno">  971</span>&#160;<span class="preprocessor">#define PN_FLAGS_ALLOW_INSECURE_MECHS                                           \</span></div><div class="line"><a name="l00972"></a><span class="lineno">  972</span>&#160;<span class="preprocessor">  (0x2) </span></div><div class="line"><a name="l00984"></a><span class="lineno">  984</span>&#160;<span class="preprocessor">PNX_EXTERN int pn_messenger_set_flags(pn_messenger_t *messenger,</span></div><div class="line"><a name="l00985"></a><span class="lineno
 ">  985</span>&#160;                                     <span class="keyword">const</span> <span class="keywordtype">int</span> flags);</div><div class="line"><a name="l00986"></a><span class="lineno">  986</span>&#160;</div><div class="line"><a name="l00993"></a><span class="lineno">  993</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga9f4e2fbfb7eb7bfd9acd7ad758d24085">pn_messenger_get_flags</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger);</div><div class="line"><a name="l00994"></a><span class="lineno">  994</span>&#160;</div><div class="line"><a name="l01001"></a><span class="lineno"> 1001</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#ga7b0872d6712c53e307bf2babfd91bf6e">pn_messenger_set_snd_settle_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t
 </a> *messenger,</div><div class="line"><a name="l01002"></a><span class="lineno"> 1002</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="group__link.html#ga3fb58bd0b88d37407ebb615c2630e608">pn_snd_settle_mode_t</a> mode);</div><div class="line"><a name="l01003"></a><span class="lineno"> 1003</span>&#160;</div><div class="line"><a name="l01010"></a><span class="lineno"> 1010</span>&#160;PNX_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__messenger.html#gae9f2d3ab15602b27f1b87a4f6349a9f1">pn_messenger_set_rcv_settle_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01011"></a><span class="lineno"> 1011</span>&#160;                                               <span class="keyword">const</span> <a class="code" href="group__link.html#gad1c2388cdae687be26222a5d66fd2d58">pn_rcv_settle_mode_t</a> 
 mode);</div><div class="line"><a name="l01012"></a><span class="lineno"> 1012</span>&#160;</div><div class="line"><a name="l01019"></a><span class="lineno"> 1019</span>&#160;PNX_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__messenger.html#ga6c2cfb88f59980bb13821a6f25cf30f6">pn_messenger_set_tracer</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01020"></a><span class="lineno"> 1020</span>&#160;                                       <a class="code" href="group__transport.html#gae9b49fcbf6397e6916eb4e1357c90ff3">pn_tracer_t</a> tracer);</div><div class="line"><a name="l01021"></a><span class="lineno"> 1021</span>&#160;</div><div class="line"><a name="l01029"></a><span class="lineno"> 1029</span>&#160;PNX_EXTERN <a class="code" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a></div><div class="line"><a name="l01030"></a><span cla
 ss="lineno"> 1030</span>&#160;    <a class="code" href="group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7">pn_messenger_get_remote_idle_timeout</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger,</div><div class="line"><a name="l01031"></a><span class="lineno"> 1031</span>&#160;                                         <span class="keyword">const</span> <span class="keywordtype">char</span> *address);</div><div class="line"><a name="l01032"></a><span class="lineno"> 1032</span>&#160;</div><div class="line"><a name="l01042"></a><span class="lineno"> 1042</span>&#160;PNX_EXTERN <span class="keywordtype">int</span></div><div class="line"><a name="l01043"></a><span class="lineno"> 1043</span>&#160;<a class="code" href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">pn_messenger_set_ssl_peer_authentication_mode</a>(<a class="code" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t<
 /a> *messenger,</div><div class="line"><a name="l01044"></a><span class="lineno"> 1044</span>&#160;                                              <span class="keyword">const</span> <a class="code" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode);</div><div class="line"><a name="l01045"></a><span class="lineno"> 1045</span>&#160;</div><div class="line"><a name="l01050"></a><span class="lineno"> 1050</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l01051"></a><span class="lineno"> 1051</span>&#160;}</div><div class="line"><a name="l01052"></a><span class="lineno"> 1052</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l01053"></a><span class="lineno"> 1053</span>&#160;</div><div class="line"><a name="l01054"></a><span class="lineno"> 1054</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* messenger.h */</span><span class="preprocessor"><
 /span></div><div class="ttc" id="group__messenger_html_ga083ba6296a1ae1dfe45c0fb82da823eb"><div class="ttname"><a href="group__messenger.html#ga083ba6296a1ae1dfe45c0fb82da823eb">pn_messenger_get_timeout</a></div><div class="ttdeci">int pn_messenger_get_timeout(pn_messenger_t *messenger)</div><div class="ttdoc">Gets the timeout for a messenger object. </div></div>
 <div class="ttc" id="group__messenger_html_gae351d031d2ef29bdb137a59d461c4253"><div class="ttname"><a href="group__messenger.html#gae351d031d2ef29bdb137a59d461c4253">pn_messenger_incoming_subscription</a></div><div class="ttdeci">pn_subscription_t * pn_messenger_incomi

<TRUNCATED>

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


[15/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.html
index 75f1f3c..79ce090 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.html
@@ -130,7 +130,6 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <tr class="memdesc:a9b9ad83418de47f87c6c7062eaefb5b6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Enable or disable automatic acceptance of messages that aren't otherwise released, rejected, or modified.  <a href="#a9b9ad83418de47f87c6c7062eaefb5b6">More...</a><br /></td></tr>
 <tr class="separator:a9b9ad83418de47f87c6c7062eaefb5b6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:af313abfa8d5b19e4b61c779907eb9980"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1receiver__options.html#af313abfa8d5b19e4b61c779907eb9980">auto_settle</a> (bool)</td></tr>
-<tr class="memdesc:af313abfa8d5b19e4b61c779907eb9980"><td class="mdescLeft">&#160;</td><td class="mdescRight">Enable or disable automatic settlement of messages.  <a href="#af313abfa8d5b19e4b61c779907eb9980">More...</a><br /></td></tr>
 <tr class="separator:af313abfa8d5b19e4b61c779907eb9980"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a7e2689fd52f88f551d11face38a4157b"><td class="memItemLeft" align="right" valign="top"><a id="a7e2689fd52f88f551d11face38a4157b"></a>
 <a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1receiver__options.html#a7e2689fd52f88f551d11face38a4157b">source</a> (<a class="el" href="classproton_1_1source__options.html">source_options</a> &amp;)</td></tr>
@@ -143,13 +142,17 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <tr class="memitem:a714a6a7dd1ea90c6046fe0460d2ce4f0"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1receiver__options.html#a714a6a7dd1ea90c6046fe0460d2ce4f0">credit_window</a> (int count)</td></tr>
 <tr class="memdesc:a714a6a7dd1ea90c6046fe0460d2ce4f0"><td class="mdescLeft">&#160;</td><td class="mdescRight">Automatically replenish credit for flow control up to <code>count</code> messages.  <a href="#a714a6a7dd1ea90c6046fe0460d2ce4f0">More...</a><br /></td></tr>
 <tr class="separator:a714a6a7dd1ea90c6046fe0460d2ce4f0"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a038ed50e63983958b13e42d49d270b88"><td class="memItemLeft" align="right" valign="top"><a id="a038ed50e63983958b13e42d49d270b88"></a>
+<a class="el" href="classproton_1_1receiver__options.html">receiver_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1receiver__options.html#a038ed50e63983958b13e42d49d270b88">name</a> (const std::string &amp;name)</td></tr>
+<tr class="memdesc:a038ed50e63983958b13e42d49d270b88"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set the link name. If not set a unique name is generated. <br /></td></tr>
+<tr class="separator:a038ed50e63983958b13e42d49d270b88"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>Options for creating a receiver. </p>
 <p>Options can be "chained" like this:</p>
-<div class="fragment"><div class="line">l = container.create_receiver(url, <a class="code" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a>().<a class="code" href="classproton_1_1receiver__options.html#a84f38ac0f31f74011c9dc342e44a53df">handler</a>(h).<a class="code" href="classproton_1_1receiver__options.html#af313abfa8d5b19e4b61c779907eb9980">auto_settle</a>(<span class="keyword">true</span>));</div></div><!-- fragment --><p>You can also create an options object with common settings and use it as a base for different connections that have mostly the same settings:</p>
-<div class="fragment"><div class="line"><a class="code" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a> opts;</div><div class="line">opts.auto_settle(<span class="keyword">true</span>);</div><div class="line">c2 = container.open_receiver(url2, opts.handler(h2));</div></div><!-- fragment --><p>Normal value semantics: copy or assign creates a separate copy of the options. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a18">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a0">client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a19">multithreaded_client_flow_control.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a3">service_bus.cpp</a>.</dd>
+<div class="fragment"><div class="line">l = container.create_receiver(url, <a class="code" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a>().<a class="code" href="classproton_1_1receiver__options.html#a84f38ac0f31f74011c9dc342e44a53df">handler</a>(h).<a class="code" href="classproton_1_1receiver__options.html#a9b9ad83418de47f87c6c7062eaefb5b6">auto_accept</a>(<span class="keyword">true</span>));</div></div><!-- fragment --><p>You can also create an options object with common settings and use it as a base for different connections that have mostly the same settings:</p>
+<div class="fragment"><div class="line"><a class="code" href="classproton_1_1receiver__options.html#a9e10a473b92db75e78a3ad8498f32c36">receiver_options</a> opts;</div><div class="line">opts.auto_accept(<span class="keyword">true</span>);</div><div class="line">c2 = container.open_receiver(url2, opts.handler(h2));</div></div><!-- fragment --><p>Normal value semantics: copy or assign creates a separate copy of the options. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a16">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a0">client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a19">multithreaded_client_flow_control.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a3">service_bus.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a84f38ac0f31f74011c9dc342e44a53df"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a84f38ac0f31f74011c9dc342e44a53df">&#9670;&nbsp;</a></span>handler()</h2>
@@ -168,7 +171,7 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 </div><div class="memdoc">
 
 <p>Set a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">messaging_handler</a> for receiver events only. </p>
-<p>The handler is no longer in use when <a class="el" href="classproton_1_1messaging__handler.html#a77ac5c1fd05404728451cd06dee1c907" title="The remote peer closed the link. ">messaging_handler::on_receiver_close()</a> is called. </p>
+<p>The handler is no longer in use when <a class="el" href="classproton_1_1messaging__handler.html#ae51075d0f1d0c180bc8098370957ae28" title="The remote peer closed the link. ">messaging_handler::on_receiver_close()</a> is called. </p>
 
 </div>
 </div>
@@ -229,9 +232,7 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
         </tr>
       </table>
 </div><div class="memdoc">
-
-<p>Enable or disable automatic settlement of messages. </p>
-<p>It is enabled by default. </p>
+<dl class="deprecated"><dt><b><a class="el" href="deprecated.html#_deprecated000001">Deprecated:</a></b></dt><dd>not applicable to receiver, only to sender </dd></dl>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.js
index e87fef6..afd7f6d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1receiver__options.js
@@ -11,5 +11,6 @@ var classproton_1_1receiver__options =
     [ "auto_settle", "classproton_1_1receiver__options.html#af313abfa8d5b19e4b61c779907eb9980", null ],
     [ "source", "classproton_1_1receiver__options.html#a7e2689fd52f88f551d11face38a4157b", null ],
     [ "target", "classproton_1_1receiver__options.html#a7823f6c72dc78481be578de1658b99eb", null ],
-    [ "credit_window", "classproton_1_1receiver__options.html#a714a6a7dd1ea90c6046fe0460d2ce4f0", null ]
+    [ "credit_window", "classproton_1_1receiver__options.html#a714a6a7dd1ea90c6046fe0460d2ce4f0", null ],
+    [ "name", "classproton_1_1receiver__options.html#a038ed50e63983958b13e42d49d270b88", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1returned.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1returned.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1returned.html
index 0266e46..4eccbbf 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1returned.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1returned.html
@@ -104,8 +104,9 @@ $(document).ready(function(){initNavTree('classproton_1_1returned.html','');});
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
-<tr class="memitem:a7e6c2d7eb0ba9807a9fb9fee0f628508"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1returned.html#a7e6c2d7eb0ba9807a9fb9fee0f628508">returned</a> (const <a class="el" href="classproton_1_1returned.html">returned</a>&lt; T &gt; &amp;)</td></tr>
-<tr class="memdesc:a7e6c2d7eb0ba9807a9fb9fee0f628508"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy operator required to return a value.  <a href="#a7e6c2d7eb0ba9807a9fb9fee0f628508">More...</a><br /></td></tr>
+<tr class="memitem:a7e6c2d7eb0ba9807a9fb9fee0f628508"><td class="memItemLeft" align="right" valign="top"><a id="a7e6c2d7eb0ba9807a9fb9fee0f628508"></a>
+&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1returned.html#a7e6c2d7eb0ba9807a9fb9fee0f628508">returned</a> (const <a class="el" href="classproton_1_1returned.html">returned</a>&lt; T &gt; &amp;)</td></tr>
+<tr class="memdesc:a7e6c2d7eb0ba9807a9fb9fee0f628508"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy operator required to return a value. <br /></td></tr>
 <tr class="separator:a7e6c2d7eb0ba9807a9fb9fee0f628508"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a54724b9dd792a6022b918eae2f393734"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1returned.html#a54724b9dd792a6022b918eae2f393734">operator T</a> () const</td></tr>
 <tr class="memdesc:a54724b9dd792a6022b918eae2f393734"><td class="mdescLeft">&#160;</td><td class="mdescRight">Convert to the proton::object.  <a href="#a54724b9dd792a6022b918eae2f393734">More...</a><br /></td></tr>
@@ -117,29 +118,7 @@ class proton::returned&lt; T &gt;</h3>
 
 <p>A return type for container methods. </p>
 <p><b>Thread safety</b> - Container method return values are <em>thread-unsafe</em>. A single-threaded application can safely assign the <code>returned&lt;T&gt;</code> value to a plain <code>T</code>. A multithreaded application <em>must</em> ignore the returned value because it may already be invalid by the time the function returns. Multithreaded applications can safely access the value inside <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> functions. </p>
-</div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
-<a id="a7e6c2d7eb0ba9807a9fb9fee0f628508"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a7e6c2d7eb0ba9807a9fb9fee0f628508">&#9670;&nbsp;</a></span>returned()</h2>
-
-<div class="memitem">
-<div class="memproto">
-      <table class="memname">
-        <tr>
-          <td class="memname"><a class="el" href="classproton_1_1returned.html">returned</a> </td>
-          <td>(</td>
-          <td class="paramtype">const <a class="el" href="classproton_1_1returned.html">returned</a>&lt; T &gt; &amp;&#160;</td>
-          <td class="paramname"></td><td>)</td>
-          <td></td>
-        </tr>
-      </table>
-</div><div class="memdoc">
-
-<p>Copy operator required to return a value. </p>
-<dl class="section note"><dt>Note</dt><dd>Thread-safe </dd></dl>
-
-</div>
-</div>
-<h2 class="groupheader">Member Function Documentation</h2>
+</div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a54724b9dd792a6022b918eae2f393734"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a54724b9dd792a6022b918eae2f393734">&#9670;&nbsp;</a></span>operator T()</h2>
 

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl-members.html
index f29ed9c..b9f6a9a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl-members.html
@@ -100,13 +100,9 @@ $(document).ready(function(){initNavTree('classproton_1_1sasl.html','');});
   <tr><td class="entry"><a class="el" href="classproton_1_1sasl.html#ae4d8c99395936130ece8495be232b9c2">mech</a>() const</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acdac157bdf0b85a40d2619cbc8bc1ae5fe2">NONE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda2bc49ec37d6a5715dd23e85f1ff5bb59">OK</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>operator=</b>(const sasl &amp;)=delete (defined in <a class="el" href="classproton_1_1sasl.html">sasl</a>)</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>operator=</b>(sasl &amp;&amp;)=delete (defined in <a class="el" href="classproton_1_1sasl.html">sasl</a>)</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acd">outcome</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1sasl.html#aee5a4997bbfa58f1b8176f936618de00">outcome</a>() const</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acdae0a57d717d9f8c8fdba757be1b0afdcf">PERM</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>sasl</b>()=delete (defined in <a class="el" href="classproton_1_1sasl.html">sasl</a>)</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>sasl</b>(const sasl &amp;)=delete (defined in <a class="el" href="classproton_1_1sasl.html">sasl</a>)</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda69a8d053cf3b5b28fa0c7dde6f883e10">SYS</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda5937389a60030a604f0efdf5e3927325">TEMP</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1sasl.html#a9444df7d81bd265e0a8e1726fd12b058">user</a>() const</td><td class="entry"><a class="el" href="classproton_1_1sasl.html">sasl</a></td><td class="entry"></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.html
index 1a2866a..5efa349 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.html
@@ -120,15 +120,6 @@ Public Types</h2></td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
-<tr class="memitem:af6da8cd4e28825fcfe0a8413783a5add"><td class="memItemLeft" align="right" valign="top"><a id="af6da8cd4e28825fcfe0a8413783a5add"></a>
-&#160;</td><td class="memItemRight" valign="bottom"><b>sasl</b> (const <a class="el" href="classproton_1_1sasl.html">sasl</a> &amp;)=delete</td></tr>
-<tr class="separator:af6da8cd4e28825fcfe0a8413783a5add"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a74642761208a390dc7dd63c869dc8599"><td class="memItemLeft" align="right" valign="top"><a id="a74642761208a390dc7dd63c869dc8599"></a>
-<a class="el" href="classproton_1_1sasl.html">sasl</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator=</b> (const <a class="el" href="classproton_1_1sasl.html">sasl</a> &amp;)=delete</td></tr>
-<tr class="separator:a74642761208a390dc7dd63c869dc8599"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:a615d497d6e83d12de95eff51963d551e"><td class="memItemLeft" align="right" valign="top"><a id="a615d497d6e83d12de95eff51963d551e"></a>
-<a class="el" href="classproton_1_1sasl.html">sasl</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><b>operator=</b> (<a class="el" href="classproton_1_1sasl.html">sasl</a> &amp;&amp;)=delete</td></tr>
-<tr class="separator:a615d497d6e83d12de95eff51963d551e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:aee5a4997bbfa58f1b8176f936618de00"><td class="memItemLeft" align="right" valign="top"><a id="aee5a4997bbfa58f1b8176f936618de00"></a>
 enum <a class="el" href="classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acd">outcome</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1sasl.html#aee5a4997bbfa58f1b8176f936618de00">outcome</a> () const</td></tr>
 <tr class="memdesc:aee5a4997bbfa58f1b8176f936618de00"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the outcome. <br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.js
index 69c87e2..42e0af4 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sasl.js
@@ -8,10 +8,6 @@ var classproton_1_1sasl =
       [ "PERM", "classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acdae0a57d717d9f8c8fdba757be1b0afdcf", null ],
       [ "TEMP", "classproton_1_1sasl.html#af47997198e7e7301a1cd8602c7f02acda5937389a60030a604f0efdf5e3927325", null ]
     ] ],
-    [ "sasl", "classproton_1_1sasl.html#ac1d29864665cf5b575439241353603eb", null ],
-    [ "sasl", "classproton_1_1sasl.html#af6da8cd4e28825fcfe0a8413783a5add", null ],
-    [ "operator=", "classproton_1_1sasl.html#a74642761208a390dc7dd63c869dc8599", null ],
-    [ "operator=", "classproton_1_1sasl.html#a615d497d6e83d12de95eff51963d551e", null ],
     [ "outcome", "classproton_1_1sasl.html#aee5a4997bbfa58f1b8176f936618de00", null ],
     [ "user", "classproton_1_1sasl.html#a9444df7d81bd265e0a8e1726fd12b058", null ],
     [ "mech", "classproton_1_1sasl.html#ae4d8c99395936130ece8495be232b9c2", null ]

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender.html
index 1d5258d..90e016e 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender.html
@@ -194,7 +194,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A channel for sending messages. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a1">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a3">client.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a6">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a11">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a7">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a1">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a1">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a1">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a8">scheduled_send_03.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a5">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a24">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.ht
 ml#_a1">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a1">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a3">client.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a6">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a9">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a1">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a1">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a1">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a8">scheduled_send_03.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a6">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a27">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a1">simple_send.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a9e8555112049fc2b4945120b3c45f8ab"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a9e8555112049fc2b4945120b3c45f8ab">&#9670;&nbsp;</a></span>open() <span class="overload">[1/2]</span></h2>
@@ -213,7 +213,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 
 <p>Open the sender. </p>
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a12">broker.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#a8">server_direct.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="server_direct_8cpp-example.html#a9">server_direct.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -286,7 +286,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
 
 <p>Implements <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>.</p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a14">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a10">helloworld_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a20">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a12">helloworld.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a23">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options-members.html
index 184e688..33e9f7d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options-members.html
@@ -99,13 +99,14 @@ $(document).ready(function(){initNavTree('classproton_1_1sender__options.html','
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a087eda4a18c293de85107fcfbb7ff31f">auto_settle</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#ab7dc71a7b5737c2ca642058a296292db">delivery_mode</a>(delivery_mode)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a0d94e8f4c1746780259f3eb2d1728aff">handler</a>(class messaging_handler &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a13e6aa698a300681f88a709ccb50c8f6">operator=</a>(const sender_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a619c789958ede03d0682a1a723cd7658">sender_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a258f4dd5231e0a3f048ec1f351c23cd4">sender_options</a>(const sender_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#af4bd1e60b98c766f4c822aad783162c0">source</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a7d4e83ee43fa1ee99a45f5bbe837ffcc">target</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a16b609dbb6a9df5ab7e719f0de05026b">update</a>(const sender_options &amp;other)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>~sender_options</b>() (defined in <a class="el" href="classproton_1_1sender__options.html">sender_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#af37454934677c6f0e8bbe8bb1087f1ed">name</a>(const std::string &amp;name)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a13e6aa698a300681f88a709ccb50c8f6">operator=</a>(const sender_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a619c789958ede03d0682a1a723cd7658">sender_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a258f4dd5231e0a3f048ec1f351c23cd4">sender_options</a>(const sender_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#af4bd1e60b98c766f4c822aad783162c0">source</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a7d4e83ee43fa1ee99a45f5bbe837ffcc">target</a>(const target_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1sender__options.html#a16b609dbb6a9df5ab7e719f0de05026b">update</a>(const sender_options &amp;other)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~sender_options</b>() (defined in <a class="el" href="classproton_1_1sender__options.html">sender_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1sender__options.html">sender_options</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.html
index 55930f1..a22c4a8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.html
@@ -139,13 +139,17 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <a class="el" href="classproton_1_1sender__options.html">sender_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1sender__options.html#a7d4e83ee43fa1ee99a45f5bbe837ffcc">target</a> (const <a class="el" href="classproton_1_1target__options.html">target_options</a> &amp;)</td></tr>
 <tr class="memdesc:a7d4e83ee43fa1ee99a45f5bbe837ffcc"><td class="mdescLeft">&#160;</td><td class="mdescRight">Options for the receiver node of the receiver. <br /></td></tr>
 <tr class="separator:a7d4e83ee43fa1ee99a45f5bbe837ffcc"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:af37454934677c6f0e8bbe8bb1087f1ed"><td class="memItemLeft" align="right" valign="top"><a id="af37454934677c6f0e8bbe8bb1087f1ed"></a>
+<a class="el" href="classproton_1_1sender__options.html">sender_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1sender__options.html#af37454934677c6f0e8bbe8bb1087f1ed">name</a> (const std::string &amp;name)</td></tr>
+<tr class="memdesc:af37454934677c6f0e8bbe8bb1087f1ed"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set the link name. If not set a unique name is generated. <br /></td></tr>
+<tr class="separator:af37454934677c6f0e8bbe8bb1087f1ed"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>Options for creating a sender. </p>
 <p>Options can be "chained" like this:</p>
 <div class="fragment"><div class="line">l = container.create_sender(url, <a class="code" href="classproton_1_1sender__options.html#a619c789958ede03d0682a1a723cd7658">sender_options</a>().<a class="code" href="classproton_1_1sender__options.html#a0d94e8f4c1746780259f3eb2d1728aff">handler</a>(h).<a class="code" href="classproton_1_1sender__options.html#a087eda4a18c293de85107fcfbb7ff31f">auto_settle</a>(<span class="keyword">false</span>));</div></div><!-- fragment --><p>You can also create an options object with common settings and use it as a base for different connections that have mostly the same settings:</p>
 <div class="fragment"><div class="line"><a class="code" href="classproton_1_1sender__options.html#a619c789958ede03d0682a1a723cd7658">sender_options</a> opts;</div><div class="line">opts.delivery_mode(<a class="code" href="structproton_1_1delivery__mode.html#a811fe196a5d9d37857c2f8adeeaac3c6adc975babe0d2bc27916397e614eb6624">delivery_mode::AT_MOST_ONCE</a>);</div><div class="line">l1 = container.open_sender(url1, opts.handler(h1));</div><div class="line">c2 = container.open_receiver(url2, opts.handler(h2));</div></div><!-- fragment --><p>Normal value semantics: copy or assign creates a separate copy of the options. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a13">broker.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a9">server_direct.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a2">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a11">broker.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a10">server_direct.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a2">service_bus.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a0d94e8f4c1746780259f3eb2d1728aff"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a0d94e8f4c1746780259f3eb2d1728aff">&#9670;&nbsp;</a></span>handler()</h2>
@@ -164,7 +168,7 @@ void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 </div><div class="memdoc">
 
 <p>Set a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">messaging_handler</a> for sender events only. </p>
-<p>The handler is no longer in use when <a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84" title="The remote peer closed the link. ">messaging_handler::on_sender_close()</a> is called. <a class="el" href="classproton_1_1messaging__handler.html#a7942b98699bd21e827041626ee1b5c84" title="The remote peer closed the link. ">messaging_handler::on_sender_close()</a> may not be called if a connection is aborted, in that case it should be cleaned up in its connection's <a class="el" href="classproton_1_1messaging__handler.html#a47c33c5e6c13d23f1b8a745bf7bdfa8f" title="The underlying network transport has closed. ">messaging_handler::on_transport_close()</a> </p>
+<p>The handler is no longer in use when <a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29" title="The remote peer closed the link. ">messaging_handler::on_sender_close()</a> is called. <a class="el" href="classproton_1_1messaging__handler.html#aa604b2d3dad610ded346b0dcf3ec6f29" title="The remote peer closed the link. ">messaging_handler::on_sender_close()</a> may not be called if a connection is aborted, in that case it should be cleaned up in its connection's <a class="el" href="classproton_1_1messaging__handler.html#a8a60c2f6628f44a9587deea8c8729f0f" title="The underlying network transport has closed. ">messaging_handler::on_transport_close()</a> </p>
 
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.js
index b28db82..8a2ce48 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1sender__options.js
@@ -9,5 +9,6 @@ var classproton_1_1sender__options =
     [ "delivery_mode", "classproton_1_1sender__options.html#ab7dc71a7b5737c2ca642058a296292db", null ],
     [ "auto_settle", "classproton_1_1sender__options.html#a087eda4a18c293de85107fcfbb7ff31f", null ],
     [ "source", "classproton_1_1sender__options.html#af4bd1e60b98c766f4c822aad783162c0", null ],
-    [ "target", "classproton_1_1sender__options.html#a7d4e83ee43fa1ee99a45f5bbe837ffcc", null ]
+    [ "target", "classproton_1_1sender__options.html#a7d4e83ee43fa1ee99a45f5bbe837ffcc", null ],
+    [ "name", "classproton_1_1sender__options.html#af37454934677c6f0e8bbe8bb1087f1ed", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1session.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1session.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1session.html
index f5a4040..608194f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1session.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1session.html
@@ -190,7 +190,7 @@ receiver_range&#160;</td><td class="memItemRight" valign="bottom"><a class="el"
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A container of senders and receivers. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a24">broker.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a28">broker.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a9e8555112049fc2b4945120b3c45f8ab"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a9e8555112049fc2b4945120b3c45f8ab">&#9670;&nbsp;</a></span>open() <span class="overload">[1/2]</span></h2>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source-members.html
index 2ce0098..aee0789 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source-members.html
@@ -97,29 +97,30 @@ $(document).ready(function(){initNavTree('classproton_1_1source.html','');});
 <p>This is the complete list of members for <a class="el" href="classproton_1_1source.html">source</a>, including all inherited members.</p>
 <table class="directory">
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#a4744eb217c976c199b678bb5a0d55acf">address</a>() const</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aba6788019f0f871f0aefcd5644635785">COPY</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089">distribution_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#abb1886a3a928bddfaf76dc67e3d15525">distribution_mode</a>() const</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">proton::terminus::durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">proton::terminus::expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#ad5af497ef0602d13b06773c910994fd7">filter_map</a> typedef</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#a5872b2a2f80f74a6f4f5b02791861a6d">filters</a>() const</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aed3ef32890b6da0919b57254c5206c62">MOVE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#a6cfde826a3d3092bd8a3a636e2336bbb">source</a>()</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aa876f4fb4e5f7f0c5c48fcf66c9ce7ce">UNSPECIFIED</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da07731dff0bf77faf2dc60a19c925e3c4">CONFIGURATION</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebad1b07c50c2dc77892c0254442e206a23">CONNECTION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aba6788019f0f871f0aefcd5644635785">COPY</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089">distribution_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#abb1886a3a928bddfaf76dc67e3d15525">distribution_mode</a>() const</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#a61db0571ab7d1a29ad77549ff99d6b3d">durability_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#aeb6439d6ea5d274a59dd8e90d97f31d8">proton::terminus::durability_mode</a>()</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#adcc4ef24adb8478230018c519aa636ec">dynamic</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#a348690a43df146eca928a8c06034a1eb">expiry_policy</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#afc97dbb9b04812da5be8a41eb9434904">proton::terminus::expiry_policy</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#ad5af497ef0602d13b06773c910994fd7">filter_map</a> typedef</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#a5872b2a2f80f74a6f4f5b02791861a6d">filters</a>() const</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba7201cfe403ee6d4b4b717d146e38bee1">LINK_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aed3ef32890b6da0919b57254c5206c62">MOVE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1eba3a267f9424d4d555780a8d26209c8118">NEVER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3dafdced71ad3dc05c5221439eddc3573e8">NONDURABLE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a348690a43df146eca928a8c06034a1ebac028e516a1a662691a25993ab4f86c09">SESSION_CLOSE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#a6cfde826a3d3092bd8a3a636e2336bbb">source</a>()</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>terminus</b>() (defined in <a class="el" href="classproton_1_1terminus.html">terminus</a>)</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1terminus.html#a16d54f985193a3ce6ac69ffe10e8dfb6">timeout</a>() const</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1terminus.html#a61db0571ab7d1a29ad77549ff99d6b3da9a971a7b3eb61a4e22701f1f4099909f">UNSETTLED_STATE</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1terminus.html">terminus</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aa876f4fb4e5f7f0c5c48fcf66c9ce7ce">UNSPECIFIED</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1source.html">source</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.html
index c35c4ed..f08b45a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.html
@@ -166,6 +166,10 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <tr class="memitem:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1value.html">value</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#ab503c82e36aa618e6c6fb34feaad57b8">node_properties</a> () const</td></tr>
 <tr class="memdesc:ab503c82e36aa618e6c6fb34feaad57b8"><td class="mdescLeft">&#160;</td><td class="mdescRight">Obtain a reference to the AMQP dynamic node properties for the terminus.  <a href="#ab503c82e36aa618e6c6fb34feaad57b8">More...</a><br /></td></tr>
 <tr class="separator:ab503c82e36aa618e6c6fb34feaad57b8"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memItemLeft" align="right" valign="top"><a id="a1c6bf68ea1dcbd3b2a0897adb628c1ee"></a>
+std::vector&lt; <a class="el" href="classproton_1_1symbol.html">symbol</a> &gt;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1terminus.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee">capabilities</a> () const</td></tr>
+<tr class="memdesc:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="mdescLeft">&#160;</td><td class="mdescRight">Extension capabilities that are supported/requested. <br /></td></tr>
+<tr class="separator:a1c6bf68ea1dcbd3b2a0897adb628c1ee"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A point of origin for messages. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.js
index a1dbc31..372b696 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source.js
@@ -16,5 +16,6 @@ var classproton_1_1source =
     [ "expiry_policy", "classproton_1_1source.html#afc97dbb9b04812da5be8a41eb9434904", null ],
     [ "timeout", "classproton_1_1source.html#a16d54f985193a3ce6ac69ffe10e8dfb6", null ],
     [ "dynamic", "classproton_1_1source.html#adcc4ef24adb8478230018c519aa636ec", null ],
-    [ "node_properties", "classproton_1_1source.html#ab503c82e36aa618e6c6fb34feaad57b8", null ]
+    [ "node_properties", "classproton_1_1source.html#ab503c82e36aa618e6c6fb34feaad57b8", null ],
+    [ "capabilities", "classproton_1_1source.html#a1c6bf68ea1dcbd3b2a0897adb628c1ee", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options-members.html
index 160a1ee..2a2292f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options-members.html
@@ -97,16 +97,17 @@ $(document).ready(function(){initNavTree('classproton_1_1source__options.html','
 <p>This is the complete list of members for <a class="el" href="classproton_1_1source__options.html">source_options</a>, including all inherited members.</p>
 <table class="directory">
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a36fa9e64134459cfe70707e0439ba850">address</a>(const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a41ffaf202d22b3276c15bfcf5b5c3ed6">distribution_mode</a>(enum source::distribution_mode)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a89176218ec0f2754c6499935368627ab">durability_mode</a>(enum source::durability_mode)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#ab491bddac8a47b9478c748f43ab583d7">dynamic</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#aad9e94ccdd35ae9bd3cfd730d5749760">expiry_policy</a>(enum source::expiry_policy)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a9a38c4697708d223e8163d301e92f6af">filters</a>(const source::filter_map &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a4c7e157cd06e40dd7fd243fcb47297be">operator=</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#afb2122d3d1a1f504c7cb23ea1093afcf">source_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a1d2323580261c3bce5c41cb93d72bff9">source_options</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a5fca9a55327631935b124badfebea989">timeout</a>(duration)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
-  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~source_options</b>() (defined in <a class="el" href="classproton_1_1source__options.html">source_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#aeaddb5ce3dec75cc6e55f3249adfe454">capabilities</a>(const std::vector&lt; symbol &gt; &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a41ffaf202d22b3276c15bfcf5b5c3ed6">distribution_mode</a>(enum source::distribution_mode)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a89176218ec0f2754c6499935368627ab">durability_mode</a>(enum source::durability_mode)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#ab491bddac8a47b9478c748f43ab583d7">dynamic</a>(bool)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#aad9e94ccdd35ae9bd3cfd730d5749760">expiry_policy</a>(enum source::expiry_policy)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a9a38c4697708d223e8163d301e92f6af">filters</a>(const source::filter_map &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a4c7e157cd06e40dd7fd243fcb47297be">operator=</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#afb2122d3d1a1f504c7cb23ea1093afcf">source_options</a>()</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1source__options.html#a1d2323580261c3bce5c41cb93d72bff9">source_options</a>(const source_options &amp;)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1source__options.html#a5fca9a55327631935b124badfebea989">timeout</a>(duration)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>~source_options</b>() (defined in <a class="el" href="classproton_1_1source__options.html">source_options</a>)</td><td class="entry"><a class="el" href="classproton_1_1source__options.html">source_options</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.html
index d8d3e4b..8c78cc0 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.html
@@ -123,7 +123,7 @@ Public Member Functions</h2></td></tr>
 <tr class="memdesc:ab491bddac8a47b9478c748f43ab583d7"><td class="mdescLeft">&#160;</td><td class="mdescRight">Request that a node be dynamically created by the remote peer.  <a href="#ab491bddac8a47b9478c748f43ab583d7">More...</a><br /></td></tr>
 <tr class="separator:ab491bddac8a47b9478c748f43ab583d7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a41ffaf202d22b3276c15bfcf5b5c3ed6"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1source__options.html">source_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1source__options.html#a41ffaf202d22b3276c15bfcf5b5c3ed6">distribution_mode</a> (enum <a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089">source::distribution_mode</a>)</td></tr>
-<tr class="memdesc:a41ffaf202d22b3276c15bfcf5b5c3ed6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Control whether messsages are browsed or consumed.  <a href="#a41ffaf202d22b3276c15bfcf5b5c3ed6">More...</a><br /></td></tr>
+<tr class="memdesc:a41ffaf202d22b3276c15bfcf5b5c3ed6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Control whether messages are browsed or consumed.  <a href="#a41ffaf202d22b3276c15bfcf5b5c3ed6">More...</a><br /></td></tr>
 <tr class="separator:a41ffaf202d22b3276c15bfcf5b5c3ed6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a89176218ec0f2754c6499935368627ab"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1source__options.html">source_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1source__options.html#a89176218ec0f2754c6499935368627ab">durability_mode</a> (enum <a class="el" href="classproton_1_1source.html#a61db0571ab7d1a29ad77549ff99d6b3d">source::durability_mode</a>)</td></tr>
 <tr class="memdesc:a89176218ec0f2754c6499935368627ab"><td class="mdescLeft">&#160;</td><td class="mdescRight">Control the persistence of the source node.  <a href="#a89176218ec0f2754c6499935368627ab">More...</a><br /></td></tr>
@@ -137,12 +137,16 @@ Public Member Functions</h2></td></tr>
 <tr class="memitem:a9a38c4697708d223e8163d301e92f6af"><td class="memItemLeft" align="right" valign="top"><a class="el" href="classproton_1_1source__options.html">source_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1source__options.html#a9a38c4697708d223e8163d301e92f6af">filters</a> (const <a class="el" href="classproton_1_1source.html#ad5af497ef0602d13b06773c910994fd7">source::filter_map</a> &amp;)</td></tr>
 <tr class="memdesc:a9a38c4697708d223e8163d301e92f6af"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Unsettled API</b> - Specify a filter mechanism on the source that restricts message flow to a subset of the available messages.  <a href="#a9a38c4697708d223e8163d301e92f6af">More...</a><br /></td></tr>
 <tr class="separator:a9a38c4697708d223e8163d301e92f6af"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aeaddb5ce3dec75cc6e55f3249adfe454"><td class="memItemLeft" align="right" valign="top"><a id="aeaddb5ce3dec75cc6e55f3249adfe454"></a>
+<a class="el" href="classproton_1_1source__options.html">source_options</a> &amp;&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1source__options.html#aeaddb5ce3dec75cc6e55f3249adfe454">capabilities</a> (const std::vector&lt; <a class="el" href="classproton_1_1symbol.html">symbol</a> &gt; &amp;)</td></tr>
+<tr class="memdesc:aeaddb5ce3dec75cc6e55f3249adfe454"><td class="mdescLeft">&#160;</td><td class="mdescRight">Extension capabilities that are supported/requested. <br /></td></tr>
+<tr class="separator:aeaddb5ce3dec75cc6e55f3249adfe454"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>Options for creating a source node for a sender or receiver. </p>
 <p>Options can be "chained". For more information see <a class="el" href="classproton_1_1connection__options.html">proton::connection_options</a>.</p>
 <p>Normal value semantics: copy or assign creates a separate copy of the options. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a14">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a1">client.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a10">server_direct.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a0">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a12">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a1">client.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a11">server_direct.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a0">service_bus.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
 <a id="a36fa9e64134459cfe70707e0439ba850"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a36fa9e64134459cfe70707e0439ba850">&#9670;&nbsp;</a></span>address()</h2>
@@ -202,7 +206,7 @@ Public Member Functions</h2></td></tr>
       </table>
 </div><div class="memdoc">
 
-<p>Control whether messsages are browsed or consumed. </p>
+<p>Control whether messages are browsed or consumed. </p>
 <p>The default is <a class="el" href="classproton_1_1source.html#ad049690d03cac384636e0c2055726089aed3ef32890b6da0919b57254c5206c62" title="Once transferred, the message is unavailable to other links. ">source::MOVE</a>, meaning consumed. </p>
 
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.js
index 4a1153e..7c59dcb 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1source__options.js
@@ -10,5 +10,6 @@ var classproton_1_1source__options =
     [ "durability_mode", "classproton_1_1source__options.html#a89176218ec0f2754c6499935368627ab", null ],
     [ "timeout", "classproton_1_1source__options.html#a5fca9a55327631935b124badfebea989", null ],
     [ "expiry_policy", "classproton_1_1source__options.html#aad9e94ccdd35ae9bd3cfd730d5749760", null ],
-    [ "filters", "classproton_1_1source__options.html#a9a38c4697708d223e8163d301e92f6af", null ]
+    [ "filters", "classproton_1_1source__options.html#a9a38c4697708d223e8163d301e92f6af", null ],
+    [ "capabilities", "classproton_1_1source__options.html#aeaddb5ce3dec75cc6e55f3249adfe454", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl-members.html
index 379cb1e..c7945c0 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl-members.html
@@ -100,11 +100,10 @@ $(document).ready(function(){initNavTree('classproton_1_1ssl.html','');});
   <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4aec34b0b90541576a22697631105dc847">NEW</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4">resume_status</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4a6a8b4831d126ce349ac966f2f469413f">REUSED</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#aab73a626b87b792e31ff0eee531fbcb2">ssl</a>()</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4a6ce26a62afab55d7606ad4e92428b30c">UNKNOWN</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3">verify_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3adb9333f2461b9f65dcb7346a8ceb185c">VERIFY_PEER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3a57807a2e5ed5e9858db1e84f24e91a0a">VERIFY_PEER_NAME</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4a6ce26a62afab55d7606ad4e92428b30c">UNKNOWN</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3">verify_mode</a> enum name</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3adb9333f2461b9f65dcb7346a8ceb185c">VERIFY_PEER</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1ssl.html#abe68233596c90fd29d934854560ff5f3a57807a2e5ed5e9858db1e84f24e91a0a">VERIFY_PEER_NAME</a> enum value</td><td class="entry"><a class="el" href="classproton_1_1ssl.html">ssl</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.html
index 463c6ae..9e61d11 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.html
@@ -91,7 +91,6 @@ $(document).ready(function(){initNavTree('classproton_1_1ssl.html','');});
 <div class="header">
   <div class="summary">
 <a href="#pub-types">Public Types</a> &#124;
-<a href="#pub-methods">Public Member Functions</a> &#124;
 <a href="classproton_1_1ssl-members.html">List of all members</a>  </div>
   <div class="headertitle">
 <div class="title">ssl</div>  </div>
@@ -117,13 +116,6 @@ Public Types</h2></td></tr>
  }<tr class="memdesc:a0d3f14f27a1e5af0a5f378fc1a8a8de4"><td class="mdescLeft">&#160;</td><td class="mdescRight">Outcome specifier for an attempted session resume.  <a href="classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4">More...</a><br /></td></tr>
 </td></tr>
 <tr class="separator:a0d3f14f27a1e5af0a5f378fc1a8a8de4"><td class="memSeparator" colspan="2">&#160;</td></tr>
-</table><table class="memberdecls">
-<tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
-Public Member Functions</h2></td></tr>
-<tr class="memitem:aab73a626b87b792e31ff0eee531fbcb2"><td class="memItemLeft" align="right" valign="top"><a id="aab73a626b87b792e31ff0eee531fbcb2"></a>
-&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1ssl.html#aab73a626b87b792e31ff0eee531fbcb2">ssl</a> ()</td></tr>
-<tr class="memdesc:aab73a626b87b792e31ff0eee531fbcb2"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create an empty ssl object. <br /></td></tr>
-<tr class="separator:aab73a626b87b792e31ff0eee531fbcb2"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>SSL information. </p>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.js
index 79f0ca4..c78e1da 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1ssl.js
@@ -9,6 +9,5 @@ var classproton_1_1ssl =
       [ "UNKNOWN", "classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4a6ce26a62afab55d7606ad4e92428b30c", null ],
       [ "NEW", "classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4aec34b0b90541576a22697631105dc847", null ],
       [ "REUSED", "classproton_1_1ssl.html#a0d3f14f27a1e5af0a5f378fc1a8a8de4a6a8b4831d126ce349ac966f2f469413f", null ]
-    ] ],
-    [ "ssl", "classproton_1_1ssl.html#aab73a626b87b792e31ff0eee531fbcb2", null ]
+    ] ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1symbol.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1symbol.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1symbol.html
index 24cd03e..22bfc3a 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1symbol.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1symbol.html
@@ -129,7 +129,7 @@ template&lt;class Iter &gt; </td></tr>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A string that represents the AMQP symbol type. </p>
 <p>A symbol can contain only 7-bit ASCII characters. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="message_properties_8cpp-example.html#_a3">message_properties.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a13">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="message_properties_8cpp-example.html#_a3">message_properties.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#_a14">service_bus.cpp</a>.</dd>
 </dl></div><hr/>The documentation for this class was generated from the following file:<ul>
 <li>proton/<a class="el" href="symbol_8hpp_source.html">symbol.hpp</a></li>
 </ul>


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


[34/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex2.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex2.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex2.js
index fe99a76..9139815 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex2.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex2.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX2 =
 {
-"group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81":[2,0,5,10],
-"group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81":[4,0,0,4,3],
-"group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf":[2,0,5,32],
-"group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf":[4,0,0,4,25],
-"group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d":[2,0,5,21],
-"group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d":[4,0,0,4,14],
-"group__delivery.html#ga247e3d1ac7c9096cdd28424353582962":[4,0,0,5,4],
-"group__delivery.html#ga247e3d1ac7c9096cdd28424353582962":[2,0,5,4],
-"group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f":[2,0,5,17],
-"group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f":[4,0,0,4,10],
-"group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b":[2,0,5,27],
-"group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b":[4,0,0,4,20],
-"group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33":[2,0,5,28],
-"group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33":[4,0,0,4,21],
-"group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331":[2,0,5,12],
-"group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331":[4,0,0,4,5],
-"group__delivery.html#ga404728c55cb6984dbb51956d764265a0":[2,0,5,15],
-"group__delivery.html#ga404728c55cb6984dbb51956d764265a0":[4,0,0,4,8],
-"group__delivery.html#ga407e51ff91368568d15f938b1771357c":[4,0,0,4,22],
-"group__delivery.html#ga407e51ff91368568d15f938b1771357c":[2,0,5,29],
-"group__delivery.html#ga42387f728f4817fdd393cc98315db332":[4,0,0,5,6],
-"group__delivery.html#ga42387f728f4817fdd393cc98315db332":[2,0,5,35],
-"group__delivery.html#ga44a2635392fe2e6f8869a7e1cd64db2f":[4,0,0,5,2],
-"group__delivery.html#ga44a2635392fe2e6f8869a7e1cd64db2f":[2,0,5,2],
-"group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1":[4,0,0,5,5],
-"group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1":[2,0,5,6],
-"group__delivery.html#ga516aee25357ac7cfde863bbceef02529":[2,0,5,19],
-"group__delivery.html#ga516aee25357ac7cfde863bbceef02529":[4,0,0,4,12],
-"group__delivery.html#ga533bd8dd766786695b6e71f8505252f1":[2,0,5,23],
-"group__delivery.html#ga533bd8dd766786695b6e71f8505252f1":[4,0,0,4,16],
-"group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9":[2,0,5,25],
-"group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9":[4,0,0,4,18],
-"group__delivery.html#ga570c54003c2ba18b84405737925e5176":[2,0,5,26],
-"group__delivery.html#ga570c54003c2ba18b84405737925e5176":[4,0,0,4,19],
-"group__delivery.html#ga5940110912277fbd543f8be3066be98b":[4,0,0,5,13],
-"group__delivery.html#ga5940110912277fbd543f8be3066be98b":[2,0,5,42],
-"group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac":[2,0,5,33],
-"group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac":[4,0,0,4,26],
-"group__delivery.html#ga5d0a4239487a90010403007f6cb268f0":[4,0,0,5,10],
-"group__delivery.html#ga5d0a4239487a90010403007f6cb268f0":[2,0,5,39],
-"group__delivery.html#ga628179c16c4a5f5fd7734bc1bfc6edc3":[4,0,0,5,3],
-"group__delivery.html#ga628179c16c4a5f5fd7734bc1bfc6edc3":[2,0,5,3],
-"group__delivery.html#ga62d917e8a18288fdb1719bf5488c3f53":[4,0,0,5,14],
-"group__delivery.html#ga62d917e8a18288fdb1719bf5488c3f53":[2,0,5,43],
-"group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad":[2,0,5,9],
-"group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad":[4,0,0,4,2],
-"group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5":[2,0,5,13],
-"group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5":[4,0,0,4,6],
-"group__delivery.html#ga6ffa5f235cb616c823746a592a191fdb":[4,0,0,5,18],
-"group__delivery.html#ga6ffa5f235cb616c823746a592a191fdb":[2,0,5,47],
-"group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776":[2,0,5,22],
-"group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776":[4,0,0,4,15],
-"group__delivery.html#ga73aa02fe7f66d07514d4e5e1f74f8947":[4,0,0,5,7],
-"group__delivery.html#ga73aa02fe7f66d07514d4e5e1f74f8947":[2,0,5,36],
-"group__delivery.html#ga7c5a14c31891750fcd211d90770a96d7":[4,0,0,5,12],
-"group__delivery.html#ga7c5a14c31891750fcd211d90770a96d7":[2,0,5,41],
-"group__delivery.html#ga8001f9574b5f37dff71ccfbc0524672e":[4,0,0,5,15],
-"group__delivery.html#ga8001f9574b5f37dff71ccfbc0524672e":[2,0,5,44],
-"group__delivery.html#ga805e6f4953eb559d5acfcfd7084fc4b3":[4,0,0,5,17],
-"group__delivery.html#ga805e6f4953eb559d5acfcfd7084fc4b3":[2,0,5,46],
-"group__delivery.html#ga8989de9cdcbbc7d0fadc1bba1f71d991":[4,0,0,5,8],
-"group__delivery.html#ga8989de9cdcbbc7d0fadc1bba1f71d991":[2,0,5,37],
-"group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6":[2,0,5,11],
-"group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6":[4,0,0,4,4],
-"group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df":[4,0,0,4,23],
-"group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df":[2,0,5,30],
-"group__delivery.html#ga9c168eb2b16c68d20b1e46ab904963cb":[4,0,0,5,9],
-"group__delivery.html#ga9c168eb2b16c68d20b1e46ab904963cb":[2,0,5,38],
-"group__delivery.html#gaae349c977b37b584aa62fff6515802ca":[2,0,5,0],
-"group__delivery.html#gaae349c977b37b584aa62fff6515802ca":[4,0,0,5,0],
-"group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1":[2,0,5,18],
-"group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1":[4,0,0,4,11],
-"group__delivery.html#gac64952b813a707586c6b3898e09552e4":[2,0,5,1],
-"group__delivery.html#gac64952b813a707586c6b3898e09552e4":[4,0,0,5,1],
-"group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340":[4,0,0,19,14],
-"group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340":[2,0,5,7],
-"group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638":[2,0,5,14],
-"group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638":[4,0,0,4,7],
-"group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd":[2,0,5,34],
-"group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd":[4,0,0,4,27],
-"group__delivery.html#gae4d5ce97c27e18d3dd843b829b81c585":[4,0,0,5,16],
-"group__delivery.html#gae4d5ce97c27e18d3dd843b829b81c585":[2,0,5,45],
-"group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27":[2,0,5,8],
-"group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27":[4,0,0,4,1],
-"group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898":[2,0,5,16],
-"group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898":[4,0,0,4,9],
-"group__error.html":[2,0,11],
-"group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c":[4,0,0,6,19],
-"group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c":[2,0,11,19],
-"group__error.html#ga0992aa0df5290a2ae639246b0c2f5481":[4,0,0,6,13],
-"group__error.html#ga0992aa0df5290a2ae639246b0c2f5481":[2,0,11,13],
-"group__error.html#ga15440ed9515967950fa4504a53fc0b64":[4,0,0,6,15],
-"group__error.html#ga15440ed9515967950fa4504a53fc0b64":[2,0,11,15],
-"group__error.html#ga24a289d5b32c9bd8a775600a5af83d52":[4,0,0,6,11],
-"group__error.html#ga24a289d5b32c9bd8a775600a5af83d52":[2,0,11,11],
-"group__error.html#ga3317339fb405435df42fa93d62f0e14c":[4,0,0,6,4],
-"group__error.html#ga3317339fb405435df42fa93d62f0e14c":[2,0,11,4],
-"group__error.html#ga53284958be0c328f90ca3a4a0793d965":[4,0,0,6,8],
-"group__error.html#ga53284958be0c328f90ca3a4a0793d965":[2,0,11,8],
-"group__error.html#ga5551b7172de89dc540bd7c2beedd325a":[4,0,0,6,6],
-"group__error.html#ga5551b7172de89dc540bd7c2beedd325a":[2,0,11,6],
-"group__error.html#ga59db2b3acdca714819c6450d2d5440a1":[4,0,0,6,17],
-"group__error.html#ga59db2b3acdca714819c6450d2d5440a1":[2,0,11,17],
-"group__error.html#ga5e57528759aedb00e68aafd0d025d06c":[4,0,0,6,14],
-"group__error.html#ga5e57528759aedb00e68aafd0d025d06c":[2,0,11,14],
-"group__error.html#ga5efbe6093556326613d2ccd3864a00aa":[4,0,0,6,5],
-"group__error.html#ga5efbe6093556326613d2ccd3864a00aa":[2,0,11,5],
-"group__error.html#ga664f7bdd616c30b72bd50bcc17839c81":[4,0,0,6,2],
-"group__error.html#ga664f7bdd616c30b72bd50bcc17839c81":[2,0,11,2],
-"group__error.html#ga67cbe6ebb143370e0604f5b84d716c56":[4,0,0,6,20],
-"group__error.html#ga67cbe6ebb143370e0604f5b84d716c56":[2,0,11,20],
-"group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2":[4,0,0,6,18],
-"group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2":[2,0,11,18],
-"group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2":[4,0,0,6,7],
-"group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2":[2,0,11,7],
-"group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3":[4,0,0,6,21],
-"group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3":[2,0,11,21],
-"group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3":[4,0,0,6,1],
-"group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3":[2,0,11,1],
-"group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7":[4,0,0,6,3],
-"group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7":[2,0,11,3],
-"group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d":[4,0,0,6,10],
-"group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d":[2,0,11,10],
-"group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d":[4,0,0,6,16],
-"group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d":[2,0,11,16],
-"group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64":[4,0,0,6,12],
-"group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64":[2,0,11,12],
-"group__error.html#gac73fbd2363c5f562f85dde459e631394":[4,0,0,6,0],
-"group__error.html#gac73fbd2363c5f562f85dde459e631394":[2,0,11,0],
-"group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33":[4,0,0,6,9],
-"group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33":[2,0,11,9],
-"group__event.html":[2,0,7],
-"group__event.html#ga04e6edffd24e5c865ac1f6b3529469e4":[4,0,0,7,6],
-"group__event.html#ga04e6edffd24e5c865ac1f6b3529469e4":[2,0,7,7],
-"group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c":[4,0,0,7,20],
-"group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c":[2,0,7,21],
-"group__event.html#ga14525ae84870388141898bbf57f2b151":[4,0,0,7,21],
-"group__event.html#ga14525ae84870388141898bbf57f2b151":[2,0,7,22],
-"group__event.html#ga1857c64d3f8549209b0b8ec91bf81e89":[4,0,0,7,8],
-"group__event.html#ga1857c64d3f8549209b0b8ec91bf81e89":[2,0,7,9],
-"group__event.html#ga1f3f0a01db5cce634c5d0ccd5d9b50be":[4,0,0,7,15],
-"group__event.html#ga1f3f0a01db5cce634c5d0ccd5d9b50be":[2,0,7,16],
-"group__event.html#ga2312e5cb8fc9e4bff94d7ab9d4b15c08":[4,0,0,7,5],
-"group__event.html#ga2312e5cb8fc9e4bff94d7ab9d4b15c08":[2,0,7,6],
-"group__event.html#ga3a85c046c11ce692c23b9566b022d54b":[4,0,0,7,3],
-"group__event.html#ga3a85c046c11ce692c23b9566b022d54b":[2,0,7,4],
-"group__event.html#ga4876e2eed24a4d4e4c52b99842103cda":[4,0,0,7,2],
-"group__event.html#ga4876e2eed24a4d4e4c52b99842103cda":[2,0,7,3],
-"group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52":[4,0,0,7,17],
-"group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52":[2,0,7,18],
-"group__event.html#ga554801c4fb87ae7518772a4492f307e0":[4,0,0,7,11],
-"group__event.html#ga554801c4fb87ae7518772a4492f307e0":[2,0,7,12],
-"group__event.html#ga5989cf0c187bd12899596fe06931476e":[4,0,0,7,22],
-"group__event.html#ga5989cf0c187bd12899596fe06931476e":[2,0,7,23],
-"group__event.html#ga672d5ec725787815cae9b7bc739cd6f9":[4,0,0,7,9],
-"group__event.html#ga672d5ec725787815cae9b7bc739cd6f9":[2,0,7,10],
-"group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9":[4,0,0,7,1],
-"group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9":[2,0,7,1],
-"group__event.html#ga75f230ef55f03a1f943df79279f8d111":[4,0,0,7,19],
-"group__event.html#ga75f230ef55f03a1f943df79279f8d111":[2,0,7,20],
-"group__event.html#ga7a4a24eb162059737f44e7520a0c1a54":[4,0,0,7,10],
-"group__event.html#ga7a4a24eb162059737f44e7520a0c1a54":[2,0,7,11],
-"group__event.html#ga7c7754316e257d4ce7660730953000ac":[4,0,0,7,4],
-"group__event.html#ga7c7754316e257d4ce7660730953000ac":[2,0,7,5],
-"group__event.html#ga87f3028b4888632bbd56fb71ac737ae8":[4,0,0,7,0],
-"group__event.html#ga87f3028b4888632bbd56fb71ac737ae8":[2,0,7,0],
-"group__event.html#ga905cdecedb8020bc28e648e43348b5d1":[2,0,7,2],
-"group__event.html#ga905cdecedb8020bc28e648e43348b5d1":[4,0,0,19,15],
-"group__event.html#ga9304e9c2e85cb5de23c81ae7cd8a9077":[4,0,0,7,12],
-"group__event.html#ga9304e9c2e85cb5de23c81ae7cd8a9077":[2,0,7,13],
-"group__event.html#gabf731be5b6c0d15173fd4d9a3b132121":[4,0,0,7,13],
-"group__event.html#gabf731be5b6c0d15173fd4d9a3b132121":[2,0,7,14],
-"group__event.html#gac3fbf151357d3101ac294cb675348c76":[4,0,0,7,24],
-"group__event.html#gac3fbf151357d3101ac294cb675348c76":[2,0,7,25],
-"group__event.html#gacaea54ca51885933b4987c131a3d1b0d":[4,0,0,7,14],
-"group__event.html#gacaea54ca51885933b4987c131a3d1b0d":[2,0,7,15],
-"group__event.html#gadab22668a28ff1af0d8ef82df516f94f":[4,0,0,7,7],
-"group__event.html#gadab22668a28ff1af0d8ef82df516f94f":[2,0,7,8],
-"group__event.html#gae7beda7f373660b889b61412ce429028":[4,0,0,7,23],
-"group__event.html#gae7beda7f373660b889b61412ce429028":[2,0,7,24],
-"group__event.html#gaecda1dea7e3a01c4ba246043ea438b19":[4,0,0,7,16],
-"group__event.html#gaecda1dea7e3a01c4ba246043ea438b19":[2,0,7,17],
-"group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5":[4,0,0,7,18],
-"group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5":[2,0,7,19],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c":[4,0,0,7,2,43],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c":[2,0,7,3,36],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0862b8e3613b7a2b5a08a779474df424":[4,0,0,7,2,14],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0862b8e3613b7a2b5a08a779474df424":[2,0,7,3,14],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f":[4,0,0,7,2,23],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f":[2,0,7,3,23],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f":[4,0,0,7,2,11],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f":[2,0,7,3,11],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa12d77930d6fc716f286f1fc1da17b718":[4,0,0,7,2,37],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa13fdcb0402f982fd366e58f165f376c9":[4,0,0,7,2,4],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa13fdcb0402f982fd366e58f165f376c9":[2,0,7,3,4],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e":[4,0,0,7,2,5],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e":[2,0,7,3,5],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba":[4,0,0,7,2,34],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba":[2,0,7,3,34],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657":[4,0,0,7,2,0],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657":[2,0,7,3,0],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db":[4,0,0,7,2,33],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db":[2,0,7,3,33],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0":[4,0,0,7,2,42],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0":[2,0,7,3,35],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2db304137f1cbb89baed3ff87ab43b9c":[4,0,0,7,2,36],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c":[4,0,0,7,2,19],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c":[2,0,7,3,19],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135":[4,0,0,7,2,17],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135":[2,0,7,3,17],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3b27f8d1c91cc05b47bed1905d42373a":[4,0,0,7,2,22],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3b27f8d1c91cc05b47bed1905d42373a":[2,0,7,3,22],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45de34c8f4fdb4c8b1f713d7b17b4ca1":[4,0,0,7,2,41],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307":[4,0,0,7,2,21],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307":[2,0,7,3,21],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe":[4,0,0,7,2,46],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe":[2,0,7,3,39],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f":[4,0,0,7,2,26],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f":[2,0,7,3,26],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5258331573513f2672922763ee41b24f":[4,0,0,7,2,39],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5548649935a6aab6e6547c9036f685ff":[4,0,0,7,2,2],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5548649935a6aab6e6547c9036f685ff":[2,0,7,3,2],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2":[4,0,0,7,2,25],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2":[2,0,7,3,25],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a":[4,0,0,7,2,8],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a":[2,0,7,3,8],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d3fe92cc7ef0e8712b038ecfbd05029":[4,0,0,7,2,16],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d3fe92cc7ef0e8712b038ecfbd05029":[2,0,7,3,16],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5ddecd4b0ea72895413fbf1b5cb41f65":[4,0,0,7,2,20],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5ddecd4b0ea72895413fbf1b5cb41f65":[2,0,7,3,20],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6c7d6b4e5f1e4f47fa80dae1ad686e0b":[4,0,0,7,2,12],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6c7d6b4e5f1e4f47fa80dae1ad686e0b":[2,0,7,3,12],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6dd63225befbc388ca529f5f4cf6d2b9":[4,0,0,7,2,38],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7":[4,0,0,7,2,48],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7":[2,0,7,3,41],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe":[4,0,0,7,2,28],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe":[2,0,7,3,28],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa74f3d7501f7d57e620e9d826293c47ee":[4,0,0,7,2,35],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa7c7278de5bcbf3b42b3e692ca21f6c5a":[4,0,0,7,2,31],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa7c7278de5bcbf3b42b3e692ca21f6c5a":[2,0,7,3,31],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e":[2,0,7,3,24],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e":[4,0,0,7,2,24],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b":[4,0,0,7,2,47],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b":[2,0,7,3,40],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db":[2,0,7,3,1],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db":[4,0,0,7,2,1],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51":[4,0,0,7,2,32],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51":[2,0,7,3,32],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaa205271edd307e5d33bd8287a760ad28":[4,0,0,7,2,30],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaa205271edd307e5d33bd8287a760ad28":[2,0,7,3,30]
+"group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb":[3,0,5,31],
+"group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb":[5,0,0,5,24],
+"group__delivery.html#ga102eb1d46ff8fbed816d5c619e5fa52f":[5,0,0,6,11],
+"group__delivery.html#ga102eb1d46ff8fbed816d5c619e5fa52f":[3,0,5,40],
+"group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35":[5,0,0,5,17],
+"group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35":[3,0,5,24],
+"group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40":[3,0,5,20],
+"group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40":[5,0,0,5,13],
+"group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81":[3,0,5,10],
+"group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81":[5,0,0,5,3],
+"group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf":[3,0,5,32],
+"group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf":[5,0,0,5,25],
+"group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d":[3,0,5,21],
+"group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d":[5,0,0,5,14],
+"group__delivery.html#ga247e3d1ac7c9096cdd28424353582962":[5,0,0,6,4],
+"group__delivery.html#ga247e3d1ac7c9096cdd28424353582962":[3,0,5,4],
+"group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f":[3,0,5,17],
+"group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f":[5,0,0,5,10],
+"group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b":[5,0,0,5,20],
+"group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b":[3,0,5,27],
+"group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33":[5,0,0,5,21],
+"group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33":[3,0,5,28],
+"group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331":[3,0,5,12],
+"group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331":[5,0,0,5,5],
+"group__delivery.html#ga404728c55cb6984dbb51956d764265a0":[3,0,5,15],
+"group__delivery.html#ga404728c55cb6984dbb51956d764265a0":[5,0,0,5,8],
+"group__delivery.html#ga407e51ff91368568d15f938b1771357c":[5,0,0,5,22],
+"group__delivery.html#ga407e51ff91368568d15f938b1771357c":[3,0,5,29],
+"group__delivery.html#ga42387f728f4817fdd393cc98315db332":[3,0,5,35],
+"group__delivery.html#ga42387f728f4817fdd393cc98315db332":[5,0,0,6,6],
+"group__delivery.html#ga44a2635392fe2e6f8869a7e1cd64db2f":[5,0,0,6,2],
+"group__delivery.html#ga44a2635392fe2e6f8869a7e1cd64db2f":[3,0,5,2],
+"group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1":[5,0,0,6,5],
+"group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1":[3,0,5,6],
+"group__delivery.html#ga516aee25357ac7cfde863bbceef02529":[3,0,5,19],
+"group__delivery.html#ga516aee25357ac7cfde863bbceef02529":[5,0,0,5,12],
+"group__delivery.html#ga533bd8dd766786695b6e71f8505252f1":[5,0,0,5,16],
+"group__delivery.html#ga533bd8dd766786695b6e71f8505252f1":[3,0,5,23],
+"group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9":[5,0,0,5,18],
+"group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9":[3,0,5,25],
+"group__delivery.html#ga570c54003c2ba18b84405737925e5176":[5,0,0,5,19],
+"group__delivery.html#ga570c54003c2ba18b84405737925e5176":[3,0,5,26],
+"group__delivery.html#ga5940110912277fbd543f8be3066be98b":[5,0,0,6,13],
+"group__delivery.html#ga5940110912277fbd543f8be3066be98b":[3,0,5,42],
+"group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac":[5,0,0,5,26],
+"group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac":[3,0,5,33],
+"group__delivery.html#ga5d0a4239487a90010403007f6cb268f0":[5,0,0,6,10],
+"group__delivery.html#ga5d0a4239487a90010403007f6cb268f0":[3,0,5,39],
+"group__delivery.html#ga628179c16c4a5f5fd7734bc1bfc6edc3":[5,0,0,6,3],
+"group__delivery.html#ga628179c16c4a5f5fd7734bc1bfc6edc3":[3,0,5,3],
+"group__delivery.html#ga62d917e8a18288fdb1719bf5488c3f53":[5,0,0,6,14],
+"group__delivery.html#ga62d917e8a18288fdb1719bf5488c3f53":[3,0,5,43],
+"group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad":[3,0,5,9],
+"group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad":[5,0,0,5,2],
+"group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5":[3,0,5,13],
+"group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5":[5,0,0,5,6],
+"group__delivery.html#ga6ffa5f235cb616c823746a592a191fdb":[5,0,0,6,18],
+"group__delivery.html#ga6ffa5f235cb616c823746a592a191fdb":[3,0,5,47],
+"group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776":[3,0,5,22],
+"group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776":[5,0,0,5,15],
+"group__delivery.html#ga73aa02fe7f66d07514d4e5e1f74f8947":[5,0,0,6,7],
+"group__delivery.html#ga73aa02fe7f66d07514d4e5e1f74f8947":[3,0,5,36],
+"group__delivery.html#ga7c5a14c31891750fcd211d90770a96d7":[5,0,0,6,12],
+"group__delivery.html#ga7c5a14c31891750fcd211d90770a96d7":[3,0,5,41],
+"group__delivery.html#ga8001f9574b5f37dff71ccfbc0524672e":[5,0,0,6,15],
+"group__delivery.html#ga8001f9574b5f37dff71ccfbc0524672e":[3,0,5,44],
+"group__delivery.html#ga805e6f4953eb559d5acfcfd7084fc4b3":[5,0,0,6,17],
+"group__delivery.html#ga805e6f4953eb559d5acfcfd7084fc4b3":[3,0,5,46],
+"group__delivery.html#ga8989de9cdcbbc7d0fadc1bba1f71d991":[5,0,0,6,8],
+"group__delivery.html#ga8989de9cdcbbc7d0fadc1bba1f71d991":[3,0,5,37],
+"group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6":[3,0,5,11],
+"group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6":[5,0,0,5,4],
+"group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df":[5,0,0,5,23],
+"group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df":[3,0,5,30],
+"group__delivery.html#ga9c168eb2b16c68d20b1e46ab904963cb":[5,0,0,6,9],
+"group__delivery.html#ga9c168eb2b16c68d20b1e46ab904963cb":[3,0,5,38],
+"group__delivery.html#gaae349c977b37b584aa62fff6515802ca":[5,0,0,6,0],
+"group__delivery.html#gaae349c977b37b584aa62fff6515802ca":[3,0,5,0],
+"group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1":[3,0,5,18],
+"group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1":[5,0,0,5,11],
+"group__delivery.html#gac64952b813a707586c6b3898e09552e4":[5,0,0,6,1],
+"group__delivery.html#gac64952b813a707586c6b3898e09552e4":[3,0,5,1],
+"group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340":[5,0,0,29,14],
+"group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340":[3,0,5,7],
+"group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638":[3,0,5,14],
+"group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638":[5,0,0,5,7],
+"group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd":[5,0,0,5,27],
+"group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd":[3,0,5,34],
+"group__delivery.html#gae4d5ce97c27e18d3dd843b829b81c585":[5,0,0,6,16],
+"group__delivery.html#gae4d5ce97c27e18d3dd843b829b81c585":[3,0,5,45],
+"group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27":[3,0,5,8],
+"group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27":[5,0,0,5,1],
+"group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898":[3,0,5,16],
+"group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898":[5,0,0,5,9],
+"group__error.html":[3,0,11],
+"group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c":[5,0,0,8,20],
+"group__error.html#ga00e179c24bc0954e1f01c64aa832ee2c":[3,0,11,20],
+"group__error.html#ga0992aa0df5290a2ae639246b0c2f5481":[5,0,0,8,14],
+"group__error.html#ga0992aa0df5290a2ae639246b0c2f5481":[3,0,11,14],
+"group__error.html#ga15440ed9515967950fa4504a53fc0b64":[5,0,0,8,16],
+"group__error.html#ga15440ed9515967950fa4504a53fc0b64":[3,0,11,16],
+"group__error.html#ga24a289d5b32c9bd8a775600a5af83d52":[5,0,0,8,12],
+"group__error.html#ga24a289d5b32c9bd8a775600a5af83d52":[3,0,11,12],
+"group__error.html#ga3317339fb405435df42fa93d62f0e14c":[5,0,0,8,4],
+"group__error.html#ga3317339fb405435df42fa93d62f0e14c":[3,0,11,4],
+"group__error.html#ga53284958be0c328f90ca3a4a0793d965":[5,0,0,8,8],
+"group__error.html#ga53284958be0c328f90ca3a4a0793d965":[3,0,11,8],
+"group__error.html#ga5551b7172de89dc540bd7c2beedd325a":[5,0,0,8,6],
+"group__error.html#ga5551b7172de89dc540bd7c2beedd325a":[3,0,11,6],
+"group__error.html#ga59db2b3acdca714819c6450d2d5440a1":[5,0,0,8,18],
+"group__error.html#ga59db2b3acdca714819c6450d2d5440a1":[3,0,11,18],
+"group__error.html#ga5e57528759aedb00e68aafd0d025d06c":[5,0,0,8,15],
+"group__error.html#ga5e57528759aedb00e68aafd0d025d06c":[3,0,11,15],
+"group__error.html#ga5efbe6093556326613d2ccd3864a00aa":[5,0,0,8,5],
+"group__error.html#ga5efbe6093556326613d2ccd3864a00aa":[3,0,11,5],
+"group__error.html#ga664f7bdd616c30b72bd50bcc17839c81":[5,0,0,8,2],
+"group__error.html#ga664f7bdd616c30b72bd50bcc17839c81":[3,0,11,2],
+"group__error.html#ga67cbe6ebb143370e0604f5b84d716c56":[5,0,0,8,21],
+"group__error.html#ga67cbe6ebb143370e0604f5b84d716c56":[3,0,11,21],
+"group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2":[5,0,0,8,19],
+"group__error.html#ga806d0788eeb97fd52d645cb8b75f8bf2":[3,0,11,19],
+"group__error.html#ga82db456291c2627e31becc44b733a7f0":[5,0,0,8,11],
+"group__error.html#ga82db456291c2627e31becc44b733a7f0":[3,0,11,11],
+"group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2":[5,0,0,8,7],
+"group__error.html#ga8bcf4aa6de1a6530713839bcae97d4a2":[3,0,11,7],
+"group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3":[5,0,0,8,22],
+"group__error.html#ga96ccb65768c64ee0a1b71b83e08489d3":[3,0,11,22],
+"group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3":[5,0,0,8,1],
+"group__error.html#ga9e0f51b097f94293cdbbdeb5422a27a3":[3,0,11,1],
+"group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7":[5,0,0,8,3],
+"group__error.html#gaaeef136648e1fd51c2b56c0265fa86f7":[3,0,11,3],
+"group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d":[5,0,0,8,10],
+"group__error.html#gab1f773ca03b0953de6ce3caf4c795b8d":[3,0,11,10],
+"group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d":[5,0,0,8,17],
+"group__error.html#gac5b68c9e6a637810a55c0b0e6f66c90d":[3,0,11,17],
+"group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64":[5,0,0,8,13],
+"group__error.html#gac6b84f09fac8e82bd41a62212d4d8f64":[3,0,11,13],
+"group__error.html#gac73fbd2363c5f562f85dde459e631394":[5,0,0,8,0],
+"group__error.html#gac73fbd2363c5f562f85dde459e631394":[3,0,11,0],
+"group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33":[5,0,0,8,9],
+"group__error.html#gafbb090366e9dbf9a5bb0735df1e23d33":[3,0,11,9],
+"group__event.html":[3,0,7],
+"group__event.html#ga04e6edffd24e5c865ac1f6b3529469e4":[5,0,0,9,6],
+"group__event.html#ga04e6edffd24e5c865ac1f6b3529469e4":[3,0,7,7],
+"group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c":[5,0,0,9,20],
+"group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c":[3,0,7,21],
+"group__event.html#ga14525ae84870388141898bbf57f2b151":[5,0,0,9,21],
+"group__event.html#ga14525ae84870388141898bbf57f2b151":[3,0,7,22],
+"group__event.html#ga1857c64d3f8549209b0b8ec91bf81e89":[5,0,0,9,8],
+"group__event.html#ga1857c64d3f8549209b0b8ec91bf81e89":[3,0,7,9],
+"group__event.html#ga1f3f0a01db5cce634c5d0ccd5d9b50be":[5,0,0,9,15],
+"group__event.html#ga1f3f0a01db5cce634c5d0ccd5d9b50be":[3,0,7,16],
+"group__event.html#ga2312e5cb8fc9e4bff94d7ab9d4b15c08":[5,0,0,9,5],
+"group__event.html#ga2312e5cb8fc9e4bff94d7ab9d4b15c08":[3,0,7,6],
+"group__event.html#ga3a85c046c11ce692c23b9566b022d54b":[5,0,0,9,3],
+"group__event.html#ga3a85c046c11ce692c23b9566b022d54b":[3,0,7,4],
+"group__event.html#ga4876e2eed24a4d4e4c52b99842103cda":[5,0,0,9,2],
+"group__event.html#ga4876e2eed24a4d4e4c52b99842103cda":[3,0,7,3],
+"group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52":[5,0,0,9,17],
+"group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52":[3,0,7,18],
+"group__event.html#ga554801c4fb87ae7518772a4492f307e0":[5,0,0,9,11],
+"group__event.html#ga554801c4fb87ae7518772a4492f307e0":[3,0,7,12],
+"group__event.html#ga5989cf0c187bd12899596fe06931476e":[5,0,0,9,22],
+"group__event.html#ga5989cf0c187bd12899596fe06931476e":[3,0,7,23],
+"group__event.html#ga672d5ec725787815cae9b7bc739cd6f9":[5,0,0,9,9],
+"group__event.html#ga672d5ec725787815cae9b7bc739cd6f9":[3,0,7,10],
+"group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9":[5,0,0,9,1],
+"group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9":[3,0,7,1],
+"group__event.html#ga75f230ef55f03a1f943df79279f8d111":[5,0,0,9,19],
+"group__event.html#ga75f230ef55f03a1f943df79279f8d111":[3,0,7,20],
+"group__event.html#ga7a4a24eb162059737f44e7520a0c1a54":[5,0,0,9,10],
+"group__event.html#ga7a4a24eb162059737f44e7520a0c1a54":[3,0,7,11],
+"group__event.html#ga7c7754316e257d4ce7660730953000ac":[5,0,0,9,4],
+"group__event.html#ga7c7754316e257d4ce7660730953000ac":[3,0,7,5],
+"group__event.html#ga87f3028b4888632bbd56fb71ac737ae8":[5,0,0,9,0],
+"group__event.html#ga87f3028b4888632bbd56fb71ac737ae8":[3,0,7,0],
+"group__event.html#ga905cdecedb8020bc28e648e43348b5d1":[3,0,7,2],
+"group__event.html#ga905cdecedb8020bc28e648e43348b5d1":[5,0,0,29,15],
+"group__event.html#ga9304e9c2e85cb5de23c81ae7cd8a9077":[5,0,0,9,12],
+"group__event.html#ga9304e9c2e85cb5de23c81ae7cd8a9077":[3,0,7,13],
+"group__event.html#gabf731be5b6c0d15173fd4d9a3b132121":[3,0,7,14],
+"group__event.html#gabf731be5b6c0d15173fd4d9a3b132121":[5,0,0,9,13],
+"group__event.html#gac3fbf151357d3101ac294cb675348c76":[5,0,0,9,24],
+"group__event.html#gac3fbf151357d3101ac294cb675348c76":[3,0,7,25],
+"group__event.html#gacaea54ca51885933b4987c131a3d1b0d":[5,0,0,9,14],
+"group__event.html#gacaea54ca51885933b4987c131a3d1b0d":[3,0,7,15],
+"group__event.html#gadab22668a28ff1af0d8ef82df516f94f":[5,0,0,9,7],
+"group__event.html#gadab22668a28ff1af0d8ef82df516f94f":[3,0,7,8],
+"group__event.html#gae7beda7f373660b889b61412ce429028":[5,0,0,9,23],
+"group__event.html#gae7beda7f373660b889b61412ce429028":[3,0,7,24],
+"group__event.html#gaecda1dea7e3a01c4ba246043ea438b19":[5,0,0,9,16],
+"group__event.html#gaecda1dea7e3a01c4ba246043ea438b19":[3,0,7,17],
+"group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5":[5,0,0,9,18],
+"group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5":[3,0,7,19],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c":[5,0,0,9,2,43],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c":[3,0,7,3,36],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0862b8e3613b7a2b5a08a779474df424":[5,0,0,9,2,14],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0862b8e3613b7a2b5a08a779474df424":[3,0,7,3,14],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f":[5,0,0,9,2,23],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1153f0108be071c31210dd1cd3e40a1f":[3,0,7,3,23],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f":[5,0,0,9,2,11],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f":[3,0,7,3,11],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa12d77930d6fc716f286f1fc1da17b718":[5,0,0,9,2,37],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa13fdcb0402f982fd366e58f165f376c9":[5,0,0,9,2,4],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa13fdcb0402f982fd366e58f165f376c9":[3,0,7,3,4],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e":[5,0,0,9,2,5],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e":[3,0,7,3,5],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba":[5,0,0,9,2,34],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba":[3,0,7,3,34],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657":[5,0,0,9,2,0],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1f5eec218463ae8e4f962fcc8eb2e657":[3,0,7,3,0],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db":[5,0,0,9,2,33],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa205d07df6cd3d07b37a89f046b1184db":[3,0,7,3,33],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0":[5,0,0,9,2,42],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0":[3,0,7,3,35],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2db304137f1cbb89baed3ff87ab43b9c":[5,0,0,9,2,36],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c":[5,0,0,9,2,19],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa2f9e46bded95d0233cc74a71fdc75a2c":[3,0,7,3,19],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135":[5,0,0,9,2,17],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135":[3,0,7,3,17],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3b27f8d1c91cc05b47bed1905d42373a":[5,0,0,9,2,22],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3b27f8d1c91cc05b47bed1905d42373a":[3,0,7,3,22],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45de34c8f4fdb4c8b1f713d7b17b4ca1":[5,0,0,9,2,41],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307":[5,0,0,9,2,21],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307":[3,0,7,3,21],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe":[5,0,0,9,2,46],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4afa8c2da61f4c665c669fbe37b1c5fe":[3,0,7,3,39],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f":[5,0,0,9,2,26],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f":[3,0,7,3,26],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5258331573513f2672922763ee41b24f":[5,0,0,9,2,39],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5548649935a6aab6e6547c9036f685ff":[5,0,0,9,2,2],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5548649935a6aab6e6547c9036f685ff":[3,0,7,3,2],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2":[5,0,0,9,2,25],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5a84b68a2bd5ca705187381a785121d2":[3,0,7,3,25],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a":[5,0,0,9,2,8],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d285c46982df224c3e4733b05c3540a":[3,0,7,3,8],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d3fe92cc7ef0e8712b038ecfbd05029":[5,0,0,9,2,16],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5d3fe92cc7ef0e8712b038ecfbd05029":[3,0,7,3,16],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5ddecd4b0ea72895413fbf1b5cb41f65":[5,0,0,9,2,20],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa5ddecd4b0ea72895413fbf1b5cb41f65":[3,0,7,3,20],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6c7d6b4e5f1e4f47fa80dae1ad686e0b":[5,0,0,9,2,12],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6c7d6b4e5f1e4f47fa80dae1ad686e0b":[3,0,7,3,12],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6dd63225befbc388ca529f5f4cf6d2b9":[5,0,0,9,2,38],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7":[5,0,0,9,2,48],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7":[3,0,7,3,41],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe":[5,0,0,9,2,28],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe":[3,0,7,3,28],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa74f3d7501f7d57e620e9d826293c47ee":[5,0,0,9,2,35],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa7c7278de5bcbf3b42b3e692ca21f6c5a":[5,0,0,9,2,31],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa7c7278de5bcbf3b42b3e692ca21f6c5a":[3,0,7,3,31]
 };

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/navtreeindex3.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/navtreeindex3.js b/content/releases/qpid-proton-master/proton/c/api/navtreeindex3.js
index 686c969..9b14871 100755
--- a/content/releases/qpid-proton-master/proton/c/api/navtreeindex3.js
+++ b/content/releases/qpid-proton-master/proton/c/api/navtreeindex3.js
@@ -1,253 +1,253 @@
 var NAVTREEINDEX3 =
 {
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498":[4,0,0,7,2,7],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498":[2,0,7,3,7],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86":[4,0,0,7,2,10],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86":[2,0,7,3,10],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad164b6566815866ed2c1d981e02bacb0":[4,0,0,7,2,3],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad164b6566815866ed2c1d981e02bacb0":[2,0,7,3,3],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc":[4,0,0,7,2,9],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc":[2,0,7,3,9],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca":[4,0,0,7,2,44],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca":[2,0,7,3,37],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76":[2,0,7,3,29],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76":[4,0,0,7,2,29],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaade231050bf30430bf4f2c111f5564ee0":[4,0,0,7,2,40],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5":[4,0,0,7,2,27],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5":[2,0,7,3,27],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499":[4,0,0,7,2,45],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499":[2,0,7,3,38],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f":[4,0,0,7,2,13],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f":[2,0,7,3,13],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5eb59f4d99ef5a8efd48be64a2bd8f8":[4,0,0,7,2,18],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5eb59f4d99ef5a8efd48be64a2bd8f8":[2,0,7,3,18],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5":[2,0,7,3,6],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5":[4,0,0,7,2,6],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806":[4,0,0,7,2,15],
-"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806":[2,0,7,3,15],
-"group__io.html":[2,3],
-"group__link.html":[2,0,2],
-"group__link.html#ga06c97ce7396973dca0d311567f25f95a":[4,0,0,8,47],
-"group__link.html#ga06c97ce7396973dca0d311567f25f95a":[2,0,2,48],
-"group__link.html#ga0bc65ff494e2860e6227f68c72468101":[4,0,0,8,34],
-"group__link.html#ga0bc65ff494e2860e6227f68c72468101":[2,0,2,35],
-"group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b":[4,0,0,8,20],
-"group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b":[2,0,2,21],
-"group__link.html#ga2421a9ddebba208338412dea365cf6ad":[2,0,2,51],
-"group__link.html#ga2421a9ddebba208338412dea365cf6ad":[4,0,0,8,50],
-"group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3":[4,0,0,8,21],
-"group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3":[2,0,2,22],
-"group__link.html#ga376f2cc18bbd771d95aa8222586d19b2":[4,0,0,8,6],
-"group__link.html#ga376f2cc18bbd771d95aa8222586d19b2":[2,0,2,7],
-"group__link.html#ga378e4bb5a0519a75c3c151c15809dda5":[4,0,0,8,38],
-"group__link.html#ga378e4bb5a0519a75c3c151c15809dda5":[2,0,2,39],
-"group__link.html#ga3fb58bd0b88d37407ebb615c2630e608":[4,0,0,8,0],
-"group__link.html#ga3fb58bd0b88d37407ebb615c2630e608":[2,0,2,1],
-"group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac":[4,0,0,8,30],
-"group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac":[2,0,2,31],
-"group__link.html#ga469bef2e81c53e85899ffbb277616a8c":[4,0,0,8,2],
-"group__link.html#ga469bef2e81c53e85899ffbb277616a8c":[2,0,2,3],
-"group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d":[4,0,0,8,19],
-"group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d":[2,0,2,20],
-"group__link.html#ga4a821eaf6298b94522572fad73b8e2d1":[4,0,0,8,48],
-"group__link.html#ga4a821eaf6298b94522572fad73b8e2d1":[2,0,2,49],
-"group__link.html#ga52c99044eabb7712efa2f1098c760804":[4,0,0,8,13],
-"group__link.html#ga52c99044eabb7712efa2f1098c760804":[2,0,2,14],
-"group__link.html#ga55428637f3b8c446efd5fea3f26c932d":[4,0,0,8,27],
-"group__link.html#ga55428637f3b8c446efd5fea3f26c932d":[2,0,2,28],
-"group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9":[4,0,0,8,28],
-"group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9":[2,0,2,29],
-"group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f":[4,0,0,8,3],
-"group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f":[2,0,2,4],
-"group__link.html#ga6206e3d4efe0ebe0491955006930fa18":[4,0,0,8,40],
-"group__link.html#ga6206e3d4efe0ebe0491955006930fa18":[2,0,2,41],
-"group__link.html#ga677c416a6365cedd23b43043dff0b89f":[4,0,0,8,35],
-"group__link.html#ga677c416a6365cedd23b43043dff0b89f":[2,0,2,36],
-"group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce":[4,0,0,8,41],
-"group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce":[2,0,2,42],
-"group__link.html#ga7c48ef214568267839aea04ed337926b":[4,0,0,8,9],
-"group__link.html#ga7c48ef214568267839aea04ed337926b":[2,0,2,10],
-"group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e":[4,0,0,8,16],
-"group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e":[2,0,2,17],
-"group__link.html#ga7f1742528b32c3c9609b97a3ed449639":[4,0,0,8,32],
-"group__link.html#ga7f1742528b32c3c9609b97a3ed449639":[2,0,2,33],
-"group__link.html#ga89dad3aa7934329a7ff467c636687bc0":[2,0,2,0],
-"group__link.html#ga89dad3aa7934329a7ff467c636687bc0":[4,0,0,19,13],
-"group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69":[4,0,0,8,7],
-"group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69":[2,0,2,8],
-"group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f":[4,0,0,8,37],
-"group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f":[2,0,2,38],
-"group__link.html#ga93824a3859c37463e44458cd2f63d31f":[4,0,0,8,26],
-"group__link.html#ga93824a3859c37463e44458cd2f63d31f":[2,0,2,27],
-"group__link.html#ga93e6b527743f433da2ff367c1b2c500a":[4,0,0,8,5],
-"group__link.html#ga93e6b527743f433da2ff367c1b2c500a":[2,0,2,6],
-"group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23":[4,0,0,8,31],
-"group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23":[2,0,2,32],
-"group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b":[4,0,0,8,14],
-"group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b":[2,0,2,15],
-"group__link.html#ga997c85388b9fb30151ea3b40b946e958":[4,0,0,8,22],
-"group__link.html#ga997c85388b9fb30151ea3b40b946e958":[2,0,2,23],
-"group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925":[4,0,0,8,17],
-"group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925":[2,0,2,18],
-"group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d":[2,0,2,52],
-"group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d":[4,0,0,8,51],
-"group__link.html#gaa44112980ebabbb5cbd002670073a751":[4,0,0,8,8],
-"group__link.html#gaa44112980ebabbb5cbd002670073a751":[2,0,2,9],
-"group__link.html#gaa825fac21730f3f9fff37d156e5f88e9":[4,0,0,8,43],
-"group__link.html#gaa825fac21730f3f9fff37d156e5f88e9":[2,0,2,44],
-"group__link.html#gaabaca3f5d03970a122240eebc588add6":[4,0,0,8,18],
-"group__link.html#gaabaca3f5d03970a122240eebc588add6":[2,0,2,19],
-"group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb":[4,0,0,8,29],
-"group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb":[2,0,2,30],
-"group__link.html#gab6441a917c291e68984405057eb56ab8":[4,0,0,8,36],
-"group__link.html#gab6441a917c291e68984405057eb56ab8":[2,0,2,37],
-"group__link.html#gabf61668a66ae189dbb4820da6ee30d90":[4,0,0,8,24],
-"group__link.html#gabf61668a66ae189dbb4820da6ee30d90":[2,0,2,25],
-"group__link.html#gac282341dacff892eba8e224eca5c5c52":[4,0,0,8,49],
-"group__link.html#gac282341dacff892eba8e224eca5c5c52":[2,0,2,50],
-"group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d":[4,0,0,8,15],
-"group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d":[2,0,2,16],
-"group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1":[4,0,0,8,39],
-"group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1":[2,0,2,40],
-"group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6":[4,0,0,8,33],
-"group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6":[2,0,2,34],
-"group__link.html#gad1c2388cdae687be26222a5d66fd2d58":[4,0,0,8,1],
-"group__link.html#gad1c2388cdae687be26222a5d66fd2d58":[2,0,2,2],
-"group__link.html#gad502b38bc184ad0bfaa86dede81f62c9":[4,0,0,8,11],
-"group__link.html#gad502b38bc184ad0bfaa86dede81f62c9":[2,0,2,12],
-"group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df":[4,0,0,8,45],
-"group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df":[2,0,2,46],
-"group__link.html#gad7e426b0cc4759568b3fd2b4fb176260":[4,0,0,8,25],
-"group__link.html#gad7e426b0cc4759568b3fd2b4fb176260":[2,0,2,26],
-"group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7":[4,0,0,8,4],
-"group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7":[2,0,2,5],
-"group__link.html#gadf6b8ff6223465f21a481e9287f60671":[4,0,0,8,23],
-"group__link.html#gadf6b8ff6223465f21a481e9287f60671":[2,0,2,24],
-"group__link.html#gae7045dd02f2c9450ff8737e005628d81":[2,0,2,11],
-"group__link.html#gae7045dd02f2c9450ff8737e005628d81":[4,0,0,8,10],
-"group__link.html#gaeb417e6b7e99c76f61549f5ed5519395":[4,0,0,8,46],
-"group__link.html#gaeb417e6b7e99c76f61549f5ed5519395":[2,0,2,47],
-"group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2":[4,0,0,8,42],
-"group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2":[2,0,2,43],
-"group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a":[4,0,0,8,12],
-"group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a":[2,0,2,13],
-"group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9":[4,0,0,8,44],
-"group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9":[2,0,2,45],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade":[4,0,0,8,0,0],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade":[2,0,2,1,0],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0":[4,0,0,8,0,1],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0":[2,0,2,1,1],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1":[4,0,0,8,0,2],
-"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1":[2,0,2,1,2],
-"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262":[4,0,0,8,1,0],
-"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262":[2,0,2,2,0],
-"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3":[2,0,2,2,1],
-"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3":[4,0,0,8,1,1],
-"group__listener.html":[2,3,2],
-"group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104":[4,0,0,9,5],
-"group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104":[2,3,2,6],
-"group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df":[4,0,0,9,7],
-"group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df":[2,3,2,8],
-"group__listener.html#ga68ac7072ae60612d0bca5470014bf216":[2,3,2,0],
-"group__listener.html#ga68ac7072ae60612d0bca5470014bf216":[4,0,0,19,16],
-"group__listener.html#ga994a35d101824296c6e6077f2a74ff61":[2,3,2,7],
-"group__listener.html#ga994a35d101824296c6e6077f2a74ff61":[4,0,0,9,6],
-"group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2":[4,0,0,9,3],
-"group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2":[2,3,2,4],
-"group__listener.html#gaaee3c3f3822484bc2e370406abf5b736":[2,3,2,3],
-"group__listener.html#gaaee3c3f3822484bc2e370406abf5b736":[4,0,0,9,2],
-"group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5":[4,0,0,9,0],
-"group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5":[2,3,2,1],
-"group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f":[2,3,2,5],
-"group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f":[4,0,0,9,4],
-"group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63":[4,0,0,9,1],
-"group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63":[2,3,2,2],
-"group__message.html":[2,0,4],
-"group__message.html#ga013d429f94d653bc1e00f1f438a079a6":[4,0,0,10,53],
-"group__message.html#ga013d429f94d653bc1e00f1f438a079a6":[2,0,4,53],
-"group__message.html#ga02347ad161f972e4b94567f329b53a8a":[4,0,0,10,47],
-"group__message.html#ga02347ad161f972e4b94567f329b53a8a":[2,0,4,47],
-"group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc":[4,0,0,10,42],
-"group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc":[2,0,4,42],
-"group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1":[4,0,0,10,50],
-"group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1":[2,0,4,50],
-"group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0":[4,0,0,10,18],
-"group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0":[2,0,4,18],
-"group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473":[4,0,0,10,52],
-"group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473":[2,0,4,52],
-"group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a":[2,0,4,32],
-"group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a":[4,0,0,10,32],
-"group__message.html#ga280a96bf80dd37a4062432f45e679ea1":[2,0,4,33],
-"group__message.html#ga280a96bf80dd37a4062432f45e679ea1":[4,0,0,10,33],
-"group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de":[4,0,0,10,19],
-"group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de":[2,0,4,19],
-"group__message.html#ga2ade598da4a8bb0464980ae227f29d5c":[4,0,0,10,13],
-"group__message.html#ga2ade598da4a8bb0464980ae227f29d5c":[2,0,4,13],
-"group__message.html#ga2b9e17a8c639adba856130ad714ca31a":[4,0,0,10,44],
-"group__message.html#ga2b9e17a8c639adba856130ad714ca31a":[2,0,4,44],
-"group__message.html#ga304bbec66cac6f09f01cbf7014196fd9":[4,0,0,10,46],
-"group__message.html#ga304bbec66cac6f09f01cbf7014196fd9":[2,0,4,46],
-"group__message.html#ga38ecee233f94e128bed9be3e530f27e5":[4,0,0,10,25],
-"group__message.html#ga38ecee233f94e128bed9be3e530f27e5":[2,0,4,25],
-"group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad":[4,0,0,10,49],
-"group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad":[2,0,4,49],
-"group__message.html#ga4a18377a68cc26d68141e1b1afd82a52":[2,0,4,39],
-"group__message.html#ga4a18377a68cc26d68141e1b1afd82a52":[4,0,0,10,39],
-"group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4":[4,0,0,10,43],
-"group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4":[2,0,4,43],
-"group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b":[2,0,4,41],
-"group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b":[4,0,0,10,41],
-"group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33":[4,0,0,10,28],
-"group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33":[2,0,4,28],
-"group__message.html#ga5d9367609d74ca3511d4172806eeb55b":[4,0,0,10,7],
-"group__message.html#ga5d9367609d74ca3511d4172806eeb55b":[2,0,4,7],
-"group__message.html#ga5e6769354fcb71c9053fff0045301a0e":[4,0,0,10,11],
-"group__message.html#ga5e6769354fcb71c9053fff0045301a0e":[2,0,4,11],
-"group__message.html#ga5fc42eff5ec52b83099089f5888be38d":[4,0,0,10,23],
-"group__message.html#ga5fc42eff5ec52b83099089f5888be38d":[2,0,4,23],
-"group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c":[4,0,0,10,12],
-"group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c":[2,0,4,12],
-"group__message.html#ga63bdd43b7cee8741665db999fac97a62":[2,0,4,8],
-"group__message.html#ga63bdd43b7cee8741665db999fac97a62":[4,0,0,10,8],
-"group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad":[2,0,4,10],
-"group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad":[4,0,0,10,10],
-"group__message.html#ga64240467da74892010a7282116b0b234":[4,0,0,10,16],
-"group__message.html#ga64240467da74892010a7282116b0b234":[2,0,4,16],
-"group__message.html#ga69aadbc3a80f1fa16962774e711392f8":[4,0,0,10,3],
-"group__message.html#ga69aadbc3a80f1fa16962774e711392f8":[2,0,4,3],
-"group__message.html#ga6c108bc39b13c5257671aee68ea981c7":[2,0,4,38],
-"group__message.html#ga6c108bc39b13c5257671aee68ea981c7":[4,0,0,10,38],
-"group__message.html#ga7163a0174e7c71361172a1f6387f232a":[2,0,4,45],
-"group__message.html#ga7163a0174e7c71361172a1f6387f232a":[4,0,0,10,45],
-"group__message.html#ga732b155202644a5c5be75a651a3c4fac":[4,0,0,10,0],
-"group__message.html#ga732b155202644a5c5be75a651a3c4fac":[2,0,4,0],
-"group__message.html#ga7c7a49b84141d130f885e3a6b357d65a":[4,0,0,10,31],
-"group__message.html#ga7c7a49b84141d130f885e3a6b357d65a":[2,0,4,31],
-"group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce":[4,0,0,10,37],
-"group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce":[2,0,4,37],
-"group__message.html#ga918c90a049d6b39041b0a2044f9048c6":[4,0,0,10,4],
-"group__message.html#ga918c90a049d6b39041b0a2044f9048c6":[2,0,4,4],
-"group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c":[2,0,4,22],
-"group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c":[4,0,0,10,22],
-"group__message.html#ga9ad09178e7682efde76e2d39f352dfe8":[2,0,4,6],
-"group__message.html#ga9ad09178e7682efde76e2d39f352dfe8":[4,0,0,10,6],
-"group__message.html#gaa0247560f0cd4590bc8ece20565eb611":[4,0,0,10,34],
-"group__message.html#gaa0247560f0cd4590bc8ece20565eb611":[2,0,4,34],
-"group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c":[2,0,4,24],
-"group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c":[4,0,0,10,24],
-"group__message.html#gaa8594da8507dc031b1e0e89d51a2f281":[4,0,0,10,27],
-"group__message.html#gaa8594da8507dc031b1e0e89d51a2f281":[2,0,4,27],
-"group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313":[4,0,0,10,29],
-"group__message.html#gaa9a53e784afb72ea8a4d2033f99ce313":[2,0,4,29],
-"group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e":[2,0,4,2],
-"group__message.html#gaaf98d84b9ddc1c6537dddd4c9c5b979e":[4,0,0,10,2],
-"group__message.html#gab0bae90838f4661b0c82c15f25e1e988":[2,0,4,51],
-"group__message.html#gab0bae90838f4661b0c82c15f25e1e988":[4,0,0,10,51],
-"group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2":[4,0,0,10,40],
-"group__message.html#gab7f1c0d93b93dee6c3eef730e35ef5e2":[2,0,4,40],
-"group__message.html#gac10c5d8f12e4817fec126fdb608baf53":[4,0,0,10,5],
-"group__message.html#gac10c5d8f12e4817fec126fdb608baf53":[2,0,4,5],
-"group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2":[2,0,4,15],
-"group__message.html#gac8a1e35c70d625b69e0d1769d9c898d2":[4,0,0,10,15],
-"group__message.html#gacb97f21822b058b6297bc618f6d190b0":[4,0,0,10,35]
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e":[5,0,0,9,2,24],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa838b909cce908f5769d043ba3e73e73e":[3,0,7,3,24],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b":[5,0,0,9,2,47],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b":[3,0,7,3,40],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db":[5,0,0,9,2,1],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa95e9355638399ee20a697f3f494ab7db":[3,0,7,3,1],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51":[5,0,0,9,2,32],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa98facd13835b4a1d8e878d6f13c10a51":[3,0,7,3,32],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaa205271edd307e5d33bd8287a760ad28":[5,0,0,9,2,30],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaa205271edd307e5d33bd8287a760ad28":[3,0,7,3,30],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498":[5,0,0,9,2,7],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac683ba544c12cbf36a3d3015ae818498":[3,0,7,3,7],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86":[5,0,0,9,2,10],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaac8567664d41057ae94d23776f5ecdb86":[3,0,7,3,10],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad164b6566815866ed2c1d981e02bacb0":[3,0,7,3,3],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad164b6566815866ed2c1d981e02bacb0":[5,0,0,9,2,3],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc":[5,0,0,9,2,9],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc":[3,0,7,3,9],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca":[5,0,0,9,2,44],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca":[3,0,7,3,37],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76":[5,0,0,9,2,29],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad7329eb7a015f62ce70719ea20abab76":[3,0,7,3,29],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaade231050bf30430bf4f2c111f5564ee0":[5,0,0,9,2,40],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5":[5,0,0,9,2,27],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaeacdc45bfe24b2a9da2aeed7b6effac5":[3,0,7,3,27],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499":[3,0,7,3,38],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499":[5,0,0,9,2,45],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f":[5,0,0,9,2,13],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5b92fb6331bfe63786db3950073147f":[3,0,7,3,13],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5eb59f4d99ef5a8efd48be64a2bd8f8":[5,0,0,9,2,18],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf5eb59f4d99ef5a8efd48be64a2bd8f8":[3,0,7,3,18],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5":[5,0,0,9,2,6],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5":[3,0,7,3,6],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806":[5,0,0,9,2,15],
+"group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806":[3,0,7,3,15],
+"group__io.html":[3,3],
+"group__link.html":[3,0,2],
+"group__link.html#ga06c97ce7396973dca0d311567f25f95a":[5,0,0,12,47],
+"group__link.html#ga06c97ce7396973dca0d311567f25f95a":[3,0,2,48],
+"group__link.html#ga0bc65ff494e2860e6227f68c72468101":[5,0,0,12,34],
+"group__link.html#ga0bc65ff494e2860e6227f68c72468101":[3,0,2,35],
+"group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b":[5,0,0,12,20],
+"group__link.html#ga1dc327c52ac24a0d65a17c88ce685b0b":[3,0,2,21],
+"group__link.html#ga2421a9ddebba208338412dea365cf6ad":[3,0,2,51],
+"group__link.html#ga2421a9ddebba208338412dea365cf6ad":[5,0,0,12,50],
+"group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3":[5,0,0,12,21],
+"group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3":[3,0,2,22],
+"group__link.html#ga376f2cc18bbd771d95aa8222586d19b2":[5,0,0,12,6],
+"group__link.html#ga376f2cc18bbd771d95aa8222586d19b2":[3,0,2,7],
+"group__link.html#ga378e4bb5a0519a75c3c151c15809dda5":[5,0,0,12,38],
+"group__link.html#ga378e4bb5a0519a75c3c151c15809dda5":[3,0,2,39],
+"group__link.html#ga3fb58bd0b88d37407ebb615c2630e608":[5,0,0,12,0],
+"group__link.html#ga3fb58bd0b88d37407ebb615c2630e608":[3,0,2,1],
+"group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac":[5,0,0,12,30],
+"group__link.html#ga40dd26f3d035c54056e2649aeb78d8ac":[3,0,2,31],
+"group__link.html#ga469bef2e81c53e85899ffbb277616a8c":[5,0,0,12,2],
+"group__link.html#ga469bef2e81c53e85899ffbb277616a8c":[3,0,2,3],
+"group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d":[5,0,0,12,19],
+"group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d":[3,0,2,20],
+"group__link.html#ga4a821eaf6298b94522572fad73b8e2d1":[5,0,0,12,48],
+"group__link.html#ga4a821eaf6298b94522572fad73b8e2d1":[3,0,2,49],
+"group__link.html#ga52c99044eabb7712efa2f1098c760804":[5,0,0,12,13],
+"group__link.html#ga52c99044eabb7712efa2f1098c760804":[3,0,2,14],
+"group__link.html#ga55428637f3b8c446efd5fea3f26c932d":[5,0,0,12,27],
+"group__link.html#ga55428637f3b8c446efd5fea3f26c932d":[3,0,2,28],
+"group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9":[5,0,0,12,28],
+"group__link.html#ga57a00950e2eeef378fd6c0a3b3b5bfe9":[3,0,2,29],
+"group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f":[5,0,0,12,3],
+"group__link.html#ga5e314b3e07b48ebcffbac63f265fa69f":[3,0,2,4],
+"group__link.html#ga6206e3d4efe0ebe0491955006930fa18":[5,0,0,12,40],
+"group__link.html#ga6206e3d4efe0ebe0491955006930fa18":[3,0,2,41],
+"group__link.html#ga677c416a6365cedd23b43043dff0b89f":[5,0,0,12,35],
+"group__link.html#ga677c416a6365cedd23b43043dff0b89f":[3,0,2,36],
+"group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce":[5,0,0,12,41],
+"group__link.html#ga6dc9ad6d95d1cccd6f3d29b782269cce":[3,0,2,42],
+"group__link.html#ga7c48ef214568267839aea04ed337926b":[5,0,0,12,9],
+"group__link.html#ga7c48ef214568267839aea04ed337926b":[3,0,2,10],
+"group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e":[5,0,0,12,16],
+"group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e":[3,0,2,17],
+"group__link.html#ga7f1742528b32c3c9609b97a3ed449639":[5,0,0,12,32],
+"group__link.html#ga7f1742528b32c3c9609b97a3ed449639":[3,0,2,33],
+"group__link.html#ga89dad3aa7934329a7ff467c636687bc0":[3,0,2,0],
+"group__link.html#ga89dad3aa7934329a7ff467c636687bc0":[5,0,0,29,13],
+"group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69":[5,0,0,12,7],
+"group__link.html#ga8b19ffdb7934940fa7c5fd75c5fe2d69":[3,0,2,8],
+"group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f":[5,0,0,12,37],
+"group__link.html#ga92592155f2afcf6b9aabfb4fc64c140f":[3,0,2,38],
+"group__link.html#ga93824a3859c37463e44458cd2f63d31f":[5,0,0,12,26],
+"group__link.html#ga93824a3859c37463e44458cd2f63d31f":[3,0,2,27],
+"group__link.html#ga93e6b527743f433da2ff367c1b2c500a":[3,0,2,6],
+"group__link.html#ga93e6b527743f433da2ff367c1b2c500a":[5,0,0,12,5],
+"group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23":[5,0,0,12,31],
+"group__link.html#ga95c4018a1f1fe0e7c2e7fd02fe062d23":[3,0,2,32],
+"group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b":[5,0,0,12,14],
+"group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b":[3,0,2,15],
+"group__link.html#ga997c85388b9fb30151ea3b40b946e958":[5,0,0,12,22],
+"group__link.html#ga997c85388b9fb30151ea3b40b946e958":[3,0,2,23],
+"group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925":[3,0,2,18],
+"group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925":[5,0,0,12,17],
+"group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d":[3,0,2,52],
+"group__link.html#ga9fc507fe3e207e84f2fc251cf9bd833d":[5,0,0,12,51],
+"group__link.html#gaa44112980ebabbb5cbd002670073a751":[5,0,0,12,8],
+"group__link.html#gaa44112980ebabbb5cbd002670073a751":[3,0,2,9],
+"group__link.html#gaa825fac21730f3f9fff37d156e5f88e9":[5,0,0,12,43],
+"group__link.html#gaa825fac21730f3f9fff37d156e5f88e9":[3,0,2,44],
+"group__link.html#gaabaca3f5d03970a122240eebc588add6":[5,0,0,12,18],
+"group__link.html#gaabaca3f5d03970a122240eebc588add6":[3,0,2,19],
+"group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb":[5,0,0,12,29],
+"group__link.html#gab16f14d071548c5c9ab22924ee5b1ebb":[3,0,2,30],
+"group__link.html#gab6441a917c291e68984405057eb56ab8":[5,0,0,12,36],
+"group__link.html#gab6441a917c291e68984405057eb56ab8":[3,0,2,37],
+"group__link.html#gabf61668a66ae189dbb4820da6ee30d90":[5,0,0,12,24],
+"group__link.html#gabf61668a66ae189dbb4820da6ee30d90":[3,0,2,25],
+"group__link.html#gac282341dacff892eba8e224eca5c5c52":[3,0,2,50],
+"group__link.html#gac282341dacff892eba8e224eca5c5c52":[5,0,0,12,49],
+"group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d":[3,0,2,16],
+"group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d":[5,0,0,12,15],
+"group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1":[5,0,0,12,39],
+"group__link.html#gac7309a622f3f2296261ff8fa9bc33ba1":[3,0,2,40],
+"group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6":[5,0,0,12,33],
+"group__link.html#gacef130ca5cc6eb3eec2dd48c8bf5c7e6":[3,0,2,34],
+"group__link.html#gad1c2388cdae687be26222a5d66fd2d58":[5,0,0,12,1],
+"group__link.html#gad1c2388cdae687be26222a5d66fd2d58":[3,0,2,2],
+"group__link.html#gad502b38bc184ad0bfaa86dede81f62c9":[5,0,0,12,11],
+"group__link.html#gad502b38bc184ad0bfaa86dede81f62c9":[3,0,2,12],
+"group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df":[5,0,0,12,45],
+"group__link.html#gad7ad9bc5c9ea7e8a21cd4fa472d2c8df":[3,0,2,46],
+"group__link.html#gad7e426b0cc4759568b3fd2b4fb176260":[5,0,0,12,25],
+"group__link.html#gad7e426b0cc4759568b3fd2b4fb176260":[3,0,2,26],
+"group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7":[5,0,0,12,4],
+"group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7":[3,0,2,5],
+"group__link.html#gadf6b8ff6223465f21a481e9287f60671":[5,0,0,12,23],
+"group__link.html#gadf6b8ff6223465f21a481e9287f60671":[3,0,2,24],
+"group__link.html#gae7045dd02f2c9450ff8737e005628d81":[5,0,0,12,10],
+"group__link.html#gae7045dd02f2c9450ff8737e005628d81":[3,0,2,11],
+"group__link.html#gaeb417e6b7e99c76f61549f5ed5519395":[5,0,0,12,46],
+"group__link.html#gaeb417e6b7e99c76f61549f5ed5519395":[3,0,2,47],
+"group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2":[5,0,0,12,42],
+"group__link.html#gaef3f2e4bca87f9adc70e90dce7cd42b2":[3,0,2,43],
+"group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a":[5,0,0,12,12],
+"group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a":[3,0,2,13],
+"group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9":[5,0,0,12,44],
+"group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9":[3,0,2,45],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade":[5,0,0,12,0,0],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608a8bd9806d2f8d8c1724ed26bb0543bade":[3,0,2,1,0],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0":[3,0,2,1,1],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac159f0edca565961b554768a42e82bf0":[5,0,0,12,0,1],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1":[5,0,0,12,0,2],
+"group__link.html#gga3fb58bd0b88d37407ebb615c2630e608ac33a5700d0247976b465aeb7c1437fd1":[3,0,2,1,2],
+"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262":[5,0,0,12,1,0],
+"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac22b82396bd686940dfcc861302a8262":[3,0,2,2,0],
+"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3":[3,0,2,2,1],
+"group__link.html#ggad1c2388cdae687be26222a5d66fd2d58ac79dc7f63fce078a8f0fe268c81dcaf3":[5,0,0,12,1,1],
+"group__listener.html":[3,3,2],
+"group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104":[5,0,0,13,6],
+"group__listener.html#ga17a5b8573f00e16b233c59a3bb17c104":[3,3,2,7],
+"group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070":[5,0,0,13,2],
+"group__listener.html#ga3719a4ab17b8de42fc6bfb262018d070":[3,3,2,3],
+"group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df":[5,0,0,13,8],
+"group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df":[3,3,2,9],
+"group__listener.html#ga68ac7072ae60612d0bca5470014bf216":[3,3,2,0],
+"group__listener.html#ga68ac7072ae60612d0bca5470014bf216":[5,0,0,29,16],
+"group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9":[5,0,0,13,3],
+"group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9":[3,3,2,4],
+"group__listener.html#ga994a35d101824296c6e6077f2a74ff61":[5,0,0,13,7],
+"group__listener.html#ga994a35d101824296c6e6077f2a74ff61":[3,3,2,8],
+"group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2":[5,0,0,13,4],
+"group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2":[3,3,2,5],
+"group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5":[5,0,0,13,0],
+"group__listener.html#gabba0a7d2e916188e3ec07d0acf8f3fc5":[3,3,2,1],
+"group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f":[5,0,0,13,5],
+"group__listener.html#gae94f2acd3463fc0a42b1b5dd68d9326f":[3,3,2,6],
+"group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63":[5,0,0,13,1],
+"group__listener.html#gaf5769baf81fdfa80e5c4326dd4a9ab63":[3,3,2,2],
+"group__message.html":[3,0,4],
+"group__message.html#ga013d429f94d653bc1e00f1f438a079a6":[5,0,0,15,54],
+"group__message.html#ga013d429f94d653bc1e00f1f438a079a6":[3,0,4,54],
+"group__message.html#ga02347ad161f972e4b94567f329b53a8a":[5,0,0,15,47],
+"group__message.html#ga02347ad161f972e4b94567f329b53a8a":[3,0,4,47],
+"group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc":[5,0,0,15,42],
+"group__message.html#ga0ec7ed8750b4d418c60aa77e4b1812bc":[3,0,4,42],
+"group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1":[5,0,0,15,50],
+"group__message.html#ga145c06edbcccfbe97136bfb5cb2b22b1":[3,0,4,50],
+"group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0":[3,0,4,18],
+"group__message.html#ga195472fabe3416dccf8a4bfcdacfa6c0":[5,0,0,15,18],
+"group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473":[5,0,0,15,52],
+"group__message.html#ga2173bbce3c1f4b04074e42d2fe7da473":[3,0,4,52],
+"group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a":[3,0,4,32],
+"group__message.html#ga2179a56c66e47eb65c61a8f84ae4488a":[5,0,0,15,32],
+"group__message.html#ga280a96bf80dd37a4062432f45e679ea1":[5,0,0,15,33],
+"group__message.html#ga280a96bf80dd37a4062432f45e679ea1":[3,0,4,33],
+"group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de":[5,0,0,15,19],
+"group__message.html#ga296bd7b984c4b9cfabc297ab5badf7de":[3,0,4,19],
+"group__message.html#ga2ade598da4a8bb0464980ae227f29d5c":[5,0,0,15,13],
+"group__message.html#ga2ade598da4a8bb0464980ae227f29d5c":[3,0,4,13],
+"group__message.html#ga2b9e17a8c639adba856130ad714ca31a":[5,0,0,15,44],
+"group__message.html#ga2b9e17a8c639adba856130ad714ca31a":[3,0,4,44],
+"group__message.html#ga304bbec66cac6f09f01cbf7014196fd9":[5,0,0,15,46],
+"group__message.html#ga304bbec66cac6f09f01cbf7014196fd9":[3,0,4,46],
+"group__message.html#ga38ecee233f94e128bed9be3e530f27e5":[5,0,0,15,25],
+"group__message.html#ga38ecee233f94e128bed9be3e530f27e5":[3,0,4,25],
+"group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad":[5,0,0,15,49],
+"group__message.html#ga43c7ee6ab70316145fb2bb5fcad210ad":[3,0,4,49],
+"group__message.html#ga4a18377a68cc26d68141e1b1afd82a52":[5,0,0,15,39],
+"group__message.html#ga4a18377a68cc26d68141e1b1afd82a52":[3,0,4,39],
+"group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4":[5,0,0,15,43],
+"group__message.html#ga4c33c1f6b80dd62e2b4bdf23d0b2dbf4":[3,0,4,43],
+"group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b":[5,0,0,15,41],
+"group__message.html#ga4ebc7c7e7f524f5bf36214ff0ccaa00b":[3,0,4,41],
+"group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33":[5,0,0,15,28],
+"group__message.html#ga5b9e011902e7bd3a9f94ecf52b723c33":[3,0,4,28],
+"group__message.html#ga5d9367609d74ca3511d4172806eeb55b":[5,0,0,15,7],
+"group__message.html#ga5d9367609d74ca3511d4172806eeb55b":[3,0,4,7],
+"group__message.html#ga5e6769354fcb71c9053fff0045301a0e":[5,0,0,15,11],
+"group__message.html#ga5e6769354fcb71c9053fff0045301a0e":[3,0,4,11],
+"group__message.html#ga5fc42eff5ec52b83099089f5888be38d":[5,0,0,15,23],
+"group__message.html#ga5fc42eff5ec52b83099089f5888be38d":[3,0,4,23],
+"group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c":[3,0,4,12],
+"group__message.html#ga62c632d8bd001658cf6206eb5fac7e6c":[5,0,0,15,12],
+"group__message.html#ga63bdd43b7cee8741665db999fac97a62":[3,0,4,8],
+"group__message.html#ga63bdd43b7cee8741665db999fac97a62":[5,0,0,15,8],
+"group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad":[3,0,4,10],
+"group__message.html#ga63f6065e770ddf435e38d8c0e01bc5ad":[5,0,0,15,10],
+"group__message.html#ga64240467da74892010a7282116b0b234":[3,0,4,16],
+"group__message.html#ga64240467da74892010a7282116b0b234":[5,0,0,15,16],
+"group__message.html#ga69aadbc3a80f1fa16962774e711392f8":[5,0,0,15,3],
+"group__message.html#ga69aadbc3a80f1fa16962774e711392f8":[3,0,4,3],
+"group__message.html#ga6c108bc39b13c5257671aee68ea981c7":[3,0,4,38],
+"group__message.html#ga6c108bc39b13c5257671aee68ea981c7":[5,0,0,15,38],
+"group__message.html#ga7163a0174e7c71361172a1f6387f232a":[5,0,0,15,45],
+"group__message.html#ga7163a0174e7c71361172a1f6387f232a":[3,0,4,45],
+"group__message.html#ga732b155202644a5c5be75a651a3c4fac":[5,0,0,15,0],
+"group__message.html#ga732b155202644a5c5be75a651a3c4fac":[3,0,4,0],
+"group__message.html#ga7c7a49b84141d130f885e3a6b357d65a":[5,0,0,15,31],
+"group__message.html#ga7c7a49b84141d130f885e3a6b357d65a":[3,0,4,31],
+"group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5":[3,0,4,53],
+"group__message.html#ga86cd32577f0e78bab29bd0e49869f0b5":[5,0,0,15,53],
+"group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce":[5,0,0,15,37],
+"group__message.html#ga8fdfd3daca961bbfaa7affacee6047ce":[3,0,4,37],
+"group__message.html#ga918c90a049d6b39041b0a2044f9048c6":[5,0,0,15,4],
+"group__message.html#ga918c90a049d6b39041b0a2044f9048c6":[3,0,4,4],
+"group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c":[3,0,4,22],
+"group__message.html#ga957f54f40b8a297cdf9ceee8a71b3c1c":[5,0,0,15,22],
+"group__message.html#ga9ad09178e7682efde76e2d39f352dfe8":[3,0,4,6],
+"group__message.html#ga9ad09178e7682efde76e2d39f352dfe8":[5,0,0,15,6],
+"group__message.html#gaa0247560f0cd4590bc8ece20565eb611":[5,0,0,15,34],
+"group__message.html#gaa0247560f0cd4590bc8ece20565eb611":[3,0,4,34],
+"group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c":[3,0,4,24],
+"group__message.html#gaa4f5b4884d5422123a4e6f48bf00701c":[5,0,0,15,24],
+"group__message.html#gaa8594da8507dc031b1e0e89d51a2f281":[5,0,0,15,27]
 };


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


[21/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/annotated.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/annotated.html b/content/releases/qpid-proton-master/proton/cpp/api/annotated.html
index 9de992c..1e454dd 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/annotated.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/annotated.html
@@ -128,37 +128,37 @@ $(document).ready(function(){initNavTree('annotated.html','');});
 <tr id="row_0_22_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1message.html" target="_self">message</a></td><td class="desc">An AMQP message </td></tr>
 <tr id="row_0_23_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1message__id.html" target="_self">message_id</a></td><td class="desc">An AMQP message ID </td></tr>
 <tr id="row_0_24_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1messaging__handler.html" target="_self">messaging_handler</a></td><td class="desc">A handler for Proton messaging events </td></tr>
-<tr id="row_0_25_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver.html" target="_self">receiver</a></td><td class="desc">A channel for receiving messages </td></tr>
-<tr id="row_0_26_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver__options.html" target="_self">receiver_options</a></td><td class="desc">Options for creating a receiver </td></tr>
-<tr id="row_0_27_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1reconnect__options.html" target="_self">reconnect_options</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss </td></tr>
-<tr id="row_0_28_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1returned.html" target="_self">returned</a></td><td class="desc">A return type for container methods </td></tr>
-<tr id="row_0_29_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sasl.html" target="_self">sasl</a></td><td class="desc">SASL information </td></tr>
-<tr id="row_0_30_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1scalar.html" target="_self">scalar</a></td><td class="desc">A holder for an instance of any scalar AMQP type </td></tr>
-<tr id="row_0_31_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1scalar__base.html" target="_self">scalar_base</a></td><td class="desc">The base class for scalar types </td></tr>
-<tr id="row_0_32_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender.html" target="_self">sender</a></td><td class="desc">A channel for sending messages </td></tr>
-<tr id="row_0_33_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender__options.html" target="_self">sender_options</a></td><td class="desc">Options for creating a sender </td></tr>
-<tr id="row_0_34_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session.html" target="_self">session</a></td><td class="desc">A container of senders and receivers </td></tr>
-<tr id="row_0_35_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session__options.html" target="_self">session_options</a></td><td class="desc">Options for creating a session </td></tr>
-<tr id="row_0_36_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source.html" target="_self">source</a></td><td class="desc">A point of origin for messages </td></tr>
-<tr id="row_0_37_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source__options.html" target="_self">source_options</a></td><td class="desc">Options for creating a source node for a sender or receiver </td></tr>
-<tr id="row_0_38_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl.html" target="_self">ssl</a></td><td class="desc">SSL information </td></tr>
-<tr id="row_0_39_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__certificate.html" target="_self">ssl_certificate</a></td><td class="desc"><b>Unsettled API</b> - An SSL certificate </td></tr>
-<tr id="row_0_40_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__client__options.html" target="_self">ssl_client_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for outbound connections </td></tr>
-<tr id="row_0_41_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__server__options.html" target="_self">ssl_server_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for inbound connections </td></tr>
-<tr id="row_0_42_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1symbol.html" target="_self">symbol</a></td><td class="desc">A string that represents the AMQP symbol type </td></tr>
-<tr id="row_0_43_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target.html" target="_self">target</a></td><td class="desc">A destination for messages </td></tr>
-<tr id="row_0_44_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target__options.html" target="_self">target_options</a></td><td class="desc">Options for creating a target node for a sender or receiver </td></tr>
-<tr id="row_0_45_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1terminus.html" target="_self">terminus</a></td><td class="desc">One end of a link, either a source or a target </td></tr>
-<tr id="row_0_46_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="structproton_1_1timeout__error.html" target="_self">timeout_error</a></td><td class="desc">An operation timed out </td></tr>
-<tr id="row_0_47_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1timestamp.html" target="_self">timestamp</a></td><td class="desc">A 64-bit timestamp in milliseconds since the Unix epoch </td></tr>
-<tr id="row_0_48_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1tracker.html" target="_self">tracker</a></td><td class="desc">A tracker for a sent message </td></tr>
-<tr id="row_0_49_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1transfer.html" target="_self">transfer</a></td><td class="desc">The base class for delivery and tracker </td></tr>
-<tr id="row_0_50_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1transport.html" target="_self">transport</a></td><td class="desc">A network channel supporting an AMQP connection </td></tr>
-<tr id="row_0_51_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1url.html" target="_self">url</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
-<tr id="row_0_52_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="structproton_1_1url__error.html" target="_self">url_error</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
-<tr id="row_0_53_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1uuid.html" target="_self">uuid</a></td><td class="desc">A 16-byte universally unique identifier </td></tr>
-<tr id="row_0_54_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1value.html" target="_self">value</a></td><td class="desc">A holder for any AMQP value, simple or complex </td></tr>
-<tr id="row_0_55_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1work.html" target="_self">work</a></td><td class="desc"><b>Unsettled API</b> - A work item for a <a class="el" href="classproton_1_1work__queue.html">work queue</a> </td></tr>
+<tr id="row_0_25_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1null.html" target="_self">null</a></td><td class="desc">The type of the AMQP null value </td></tr>
+<tr id="row_0_26_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver.html" target="_self">receiver</a></td><td class="desc">A channel for receiving messages </td></tr>
+<tr id="row_0_27_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver__options.html" target="_self">receiver_options</a></td><td class="desc">Options for creating a receiver </td></tr>
+<tr id="row_0_28_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1reconnect__options.html" target="_self">reconnect_options</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss </td></tr>
+<tr id="row_0_29_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1returned.html" target="_self">returned</a></td><td class="desc">A return type for container methods </td></tr>
+<tr id="row_0_30_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sasl.html" target="_self">sasl</a></td><td class="desc">SASL information </td></tr>
+<tr id="row_0_31_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1scalar.html" target="_self">scalar</a></td><td class="desc">A holder for an instance of any scalar AMQP type </td></tr>
+<tr id="row_0_32_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1scalar__base.html" target="_self">scalar_base</a></td><td class="desc">The base class for scalar types </td></tr>
+<tr id="row_0_33_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender.html" target="_self">sender</a></td><td class="desc">A channel for sending messages </td></tr>
+<tr id="row_0_34_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender__options.html" target="_self">sender_options</a></td><td class="desc">Options for creating a sender </td></tr>
+<tr id="row_0_35_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session.html" target="_self">session</a></td><td class="desc">A container of senders and receivers </td></tr>
+<tr id="row_0_36_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session__options.html" target="_self">session_options</a></td><td class="desc">Options for creating a session </td></tr>
+<tr id="row_0_37_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source.html" target="_self">source</a></td><td class="desc">A point of origin for messages </td></tr>
+<tr id="row_0_38_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source__options.html" target="_self">source_options</a></td><td class="desc">Options for creating a source node for a sender or receiver </td></tr>
+<tr id="row_0_39_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl.html" target="_self">ssl</a></td><td class="desc">SSL information </td></tr>
+<tr id="row_0_40_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__certificate.html" target="_self">ssl_certificate</a></td><td class="desc"><b>Unsettled API</b> - An SSL certificate </td></tr>
+<tr id="row_0_41_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__client__options.html" target="_self">ssl_client_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for outbound connections </td></tr>
+<tr id="row_0_42_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__server__options.html" target="_self">ssl_server_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for inbound connections </td></tr>
+<tr id="row_0_43_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1symbol.html" target="_self">symbol</a></td><td class="desc">A string that represents the AMQP symbol type </td></tr>
+<tr id="row_0_44_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target.html" target="_self">target</a></td><td class="desc">A destination for messages </td></tr>
+<tr id="row_0_45_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target__options.html" target="_self">target_options</a></td><td class="desc">Options for creating a target node for a sender or receiver </td></tr>
+<tr id="row_0_46_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1terminus.html" target="_self">terminus</a></td><td class="desc">One end of a link, either a source or a target </td></tr>
+<tr id="row_0_47_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="structproton_1_1timeout__error.html" target="_self">timeout_error</a></td><td class="desc">An operation timed out </td></tr>
+<tr id="row_0_48_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1timestamp.html" target="_self">timestamp</a></td><td class="desc">A 64-bit timestamp in milliseconds since the Unix epoch </td></tr>
+<tr id="row_0_49_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1tracker.html" target="_self">tracker</a></td><td class="desc">A tracker for a sent message </td></tr>
+<tr id="row_0_50_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1transfer.html" target="_self">transfer</a></td><td class="desc">The base class for delivery and tracker </td></tr>
+<tr id="row_0_51_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1transport.html" target="_self">transport</a></td><td class="desc">A network channel supporting an AMQP connection </td></tr>
+<tr id="row_0_52_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1url.html" target="_self">url</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
+<tr id="row_0_53_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="structproton_1_1url__error.html" target="_self">url_error</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
+<tr id="row_0_54_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1uuid.html" target="_self">uuid</a></td><td class="desc">A 16-byte universally unique identifier </td></tr>
+<tr id="row_0_55_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1value.html" target="_self">value</a></td><td class="desc">A holder for any AMQP value, simple or complex </td></tr>
 <tr id="row_0_56_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1work__queue.html" target="_self">work_queue</a></td><td class="desc"><b>Unsettled API</b> - A context for thread-safe execution of work </td></tr>
 </table>
 </div><!-- directory -->


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


[02/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/messaging__handler_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/messaging__handler_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/messaging__handler_8hpp_source.html
index 2b808ee..1983dfd 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/messaging__handler_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/messaging__handler_8hpp_source.html
@@ -93,8 +93,8 @@ $(document).ready(function(){initNavTree('messaging__handler_8hpp_source.html','
 <div class="title">messaging_handler.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="messaging__handler_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGING_HANDLER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGING_HANDLER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"
 > * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="li
 neno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or impli
 ed.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;
 </span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00061"></a><span class="lineno"><a class="line" href="classproton_1_1messaging__handler.html">   61</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a> {</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00064"></a><span class="lineno
 ">   64</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>();</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> ~messaging_handler();</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_container_start(<a class="code" href="classproton_1_1container.html">container</a> &amp;c);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_container_stop(<a class="code" href="classproton_1_1container.html">container</a> &amp;c);</di
 v><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_message(<a class="code" href="classproton_1_1delivery.html">delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">message</a> &amp;m);</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sendable(<a class="code" href="classproton_1_1sender.html">sender</a> &amp;s);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keyword
 type">void</span> on_transport_open(<a class="code" href="classproton_1_1transport.html">transport</a> &amp;t);</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    </div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_transport_close(<a class="code" href="classproton_1_1transport.html">transport</a> &amp;t);</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_transport_error(<a class="code" href="classproton_1_1transport.html">transport</a> &amp;t);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    
 PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_open(<a class="code" href="classproton_1_1connection.html">connection</a> &amp;c);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_close(<a class="code" href="classproton_1_1connection.html">connection</a> &amp;c);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_error(<a class="code" href="classproton_1_1connection.html">connection</a> &amp;c);</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;</div><div c
 lass="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_open(<a class="code" href="classproton_1_1session.html">session</a> &amp;s);</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_close(<a class="code" href="classproton_1_1session.html">session</a> &amp;s);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_error(<a class="code" href="classproton_1_1session.html">session</a> &amp;s);</div><div class="line"><a name="l00108"></a><s
 pan class="lineno">  108</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp; l);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_detach(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp; l);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_close(<a class="code" href="classproton_1_1receiver.html">receiver<
 /a>&amp; l);</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_error(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp; l);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_open(<a class="code" href="classproton_1_1sender.html">sender</a>&amp; l);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_detach(<a class="
 code" href="classproton_1_1sender.html">sender</a>&amp; l);</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_close(<a class="code" href="classproton_1_1sender.html">sender</a>&amp; l);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_error(<a class="code" href="classproton_1_1sender.html">sender</a>&amp; l);</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtyp
 e">void</span> on_tracker_accept(<a class="code" href="classproton_1_1tracker.html">tracker</a> &amp;d);</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_reject(<a class="code" href="classproton_1_1tracker.html">tracker</a> &amp;d);</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_release(<a class="code" href="classproton_1_1tracker.html">tracker</a> &amp;d);</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;    PN_CPP_EXTERN <span 
 class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_settle(<a class="code" href="classproton_1_1tracker.html">tracker</a> &amp;d);</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_delivery_settle(<a class="code" href="classproton_1_1delivery.html">delivery</a> &amp;d);</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_drain_start(<a class="code" href="classproton_1_1sender.html">sender</a> &amp;s);</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;</div><div class="line"><a name="l00154"></a><span
  class="lineno">  154</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_drain_finish(<a class="code" href="classproton_1_1receiver.html">receiver</a> &amp;r);</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_wake(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_error(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a> &amp;c);</div><div class="line">
 <a name="l00174"></a><span class="lineno">  174</span>&#160;};</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;<span class="preprocessor">#endif // PROTON_MESSAGING_HANDLER_HPP</span></div><div class="ttc" id="classproton_1_1message_html"><div class="ttname"><a href="classproton_1_1message.html">proton::message</a></div><div class="ttdoc">An AMQP message. </div><div class="ttdef"><b>Definition:</b> message.hpp:50</div></div>
-<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<a href="messaging__handler_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGING_HANDLER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGING_HANDLER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"
 > * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="li
 neno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or impli
 ed.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;
 </span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno"><a class="line" href="classproton_1_1messaging__handler.html">   62</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a> {</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00065"></a><span class="lineno
 ">   65</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1messaging__handler.html">messaging_handler</a>();</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> ~messaging_handler();</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_container_start(<a class="code" href="classproton_1_1container.html">container</a>&amp;);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_container_stop(<a class="code" href="classproton_1_1container.html">container</a>&amp;);</div><d
 iv class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_message(<a class="code" href="classproton_1_1delivery.html">delivery</a>&amp;, <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sendable(<a class="code" href="classproton_1_1sender.html">sender</a>&amp;);</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void
 </span> on_transport_open(<a class="code" href="classproton_1_1transport.html">transport</a>&amp;);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_transport_close(<a class="code" href="classproton_1_1transport.html">transport</a>&amp;);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_transport_error(<a class="code" href="classproton_1_1transport.html">transport</a>&amp;);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN <span 
 class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_open(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_close(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_error(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;);</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;</div><div class="line"><a name="l0010
 6"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_open(<a class="code" href="classproton_1_1session.html">session</a>&amp;);</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_close(<a class="code" href="classproton_1_1session.html">session</a>&amp;);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_session_error(<a class="code" href="classproton_1_1session.html">session</a>&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&
 #160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_open(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp;);</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_detach(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp;);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_close(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp;);</div><div class="line"><a
  name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_error(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp;);</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_open(<a class="code" href="classproton_1_1sender.html">sender</a>&amp;);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_detach(<a class="code" href="classproton_1_1sender.html">se
 nder</a>&amp;);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_close(<a class="code" href="classproton_1_1sender.html">sender</a>&amp;);</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_error(<a class="code" href="classproton_1_1sender.html">sender</a>&amp;);</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_accept(<a class="code"
  href="classproton_1_1tracker.html">tracker</a>&amp;);</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_reject(<a class="code" href="classproton_1_1tracker.html">tracker</a>&amp;);</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_tracker_release(<a class="code" href="classproton_1_1tracker.html">tracker</a>&amp;);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtyp
 e">void</span> on_tracker_settle(<a class="code" href="classproton_1_1tracker.html">tracker</a>&amp;);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_delivery_settle(<a class="code" href="classproton_1_1delivery.html">delivery</a>&amp;);</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_sender_drain_start(<a class="code" href="classproton_1_1sender.html">sender</a>&amp;);</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;    PN_CPP_EXTERN <span cl
 ass="keyword">virtual</span> <span class="keywordtype">void</span> on_receiver_drain_finish(<a class="code" href="classproton_1_1receiver.html">receiver</a>&amp;);</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_connection_wake(<a class="code" href="classproton_1_1connection.html">connection</a>&amp;);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_error(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;);</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;};</
 div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;<span class="preprocessor">#endif // PROTON_MESSAGING_HANDLER_HPP</span></div><div class="ttc" id="classproton_1_1message_html"><div class="ttname"><a href="classproton_1_1message.html">proton::message</a></div><div class="ttdoc">An AMQP message. </div><div class="ttdef"><b>Definition:</b> message.hpp:50</div></div>
+<div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1sender_html"><div class="ttname"><a href="classproton_1_1sender.html">proton::sender</a></div><div class="ttdoc">A channel for sending messages. </div><div class="ttdef"><b>Definition:</b> sender.hpp:39</div></div>
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1connection_html"><div class="ttname"><a href="classproton_1_1connection.html">proton::connection</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div><div class="ttdef"><b>Definition:</b> connection.hpp:43</div></div>
@@ -102,7 +102,7 @@ $(document).ready(function(){initNavTree('messaging__handler_8hpp_source.html','
 <div class="ttc" id="classproton_1_1delivery_html"><div class="ttname"><a href="classproton_1_1delivery.html">proton::delivery</a></div><div class="ttdoc">A received message. </div><div class="ttdef"><b>Definition:</b> delivery.hpp:39</div></div>
 <div class="ttc" id="classproton_1_1tracker_html"><div class="ttname"><a href="classproton_1_1tracker.html">proton::tracker</a></div><div class="ttdoc">A tracker for a sent message. </div><div class="ttdef"><b>Definition:</b> tracker.hpp:40</div></div>
 <div class="ttc" id="classproton_1_1receiver_html"><div class="ttname"><a href="classproton_1_1receiver.html">proton::receiver</a></div><div class="ttdoc">A channel for receiving messages. </div><div class="ttdef"><b>Definition:</b> receiver.hpp:40</div></div>
-<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:61</div></div>
+<div class="ttc" id="classproton_1_1messaging__handler_html"><div class="ttname"><a href="classproton_1_1messaging__handler.html">proton::messaging_handler</a></div><div class="ttdoc">A handler for Proton messaging events. </div><div class="ttdef"><b>Definition:</b> messaging_handler.hpp:62</div></div>
 <div class="ttc" id="classproton_1_1transport_html"><div class="ttname"><a href="classproton_1_1transport.html">proton::transport</a></div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> transport.hpp:37</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 <div class="ttc" id="classproton_1_1error__condition_html"><div class="ttname"><a href="classproton_1_1error__condition.html">proton::error_condition</a></div><div class="ttdoc">Describes an endpoint error state. </div><div class="ttdef"><b>Definition:</b> error_condition.hpp:40</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/mt_page.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/mt_page.html b/content/releases/qpid-proton-master/proton/cpp/api/mt_page.html
index 2c5a46f..a97973f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/mt_page.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/mt_page.html
@@ -94,21 +94,19 @@ $(document).ready(function(){initNavTree('mt_page.html','');});
 </div><!--header-->
 <div class="contents">
 <div class="textblock"><p>Full multithreading support is available with C++11 and later. Limited multithreading is possible with older versions of C++. See the last section of this page for more information.</p>
+<p><code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code> handles multiple connections concurrently in a thread pool, created using <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">proton::container::run()</a></code>. As AMQP events occur on a connection the container calls <code><a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a></code> event callbacks. The calls for each connection are <em>serialized</em> - callbacks for the same connection are never made concurrently.</p>
+<p>You assign a handler to a connection in <code><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">proton::container::connect()</a></code> or <code><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc" title="Called for each accepted connection. ">proton::listen_handler::on_accept()</a></code> with <code><a class="el" href="classproton_1_1connection__options.html#a7bca23aeb3455378ef2d35975758e504" title="Set a connection handler. ">proton::connection_options::handler()</a></code>. We recommend you create a separate handler for each connection. That means the handler doesn't need locks or other synchronization to protect it against concurrent use by Proton threads. If you use the handler concurrently from non-Proton threads then you will need synchronization.</p>
+<p>The examples <a class="el" href="multithreaded_client_8cpp-example.html">multithreaded_client.cpp</a> and <a class="el" href="multithreaded_client_flow_control_8cpp-example.html">multithreaded_client_flow_control.cpp</a> illustrate these points.</p>
 <h2>Thread-safety rules</h2>
-<p><code><a class="el" href="classproton_1_1message.html" title="An AMQP message. ">proton::message</a></code> is a value type with the same threading constraints as a standard C++ built-in type. It cannot be concurrently modified.</p>
-<p>The <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code> is thread-safe <em>with C++11 or greater</em>. It has the following capabilities.</p>
-<ul>
-<li>Application threads can open (or listen for) new connections at any time.</li>
-<li>It manages worker threads to process connections.</li>
-<li>It handles network IO and calls the relevant <code><a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a></code> event callbacks to execute application code.</li>
-</ul>
-<p>The <code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code> ensures that calls to event callbacks for each connection instance are <em>serialized</em> (not called concurrently), but callbacks for different connections can be safely executed in parallel.</p>
-<p>The <code><a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a></code> and related objects (<code><a class="el" href="classproton_1_1session.html" title="A container of senders and receivers. ">proton::session</a></code>, <code><a class="el" href="classproton_1_1sender.html" title="A channel for sending messages. ">proton::sender</a></code>, <code><a class="el" href="classproton_1_1receiver.html" title="A channel for receiving messages. ">proton::receiver</a></code>, <code><a class="el" href="classproton_1_1delivery.html" title="A received message. ">proton::delivery</a></code>) are <em>not</em> thread-safe and are subject to the following rules.</p>
+<p><code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code> is thread-safe <em>with C++11 or greater</em>. An application thread can open (or listen for) new connections at any time. The container uses threads that call <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">proton::container::run()</a></code> to handle network IO and call user-defined <code><a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a></code> callbacks.</p>
+<p><code><a class="el" href="classproton_1_1container.html" title="A top-level container of connections, sessions, and links. ">proton::container</a></code> ensures that calls to event callbacks for each connection instance are <em>serialized</em> (not called concurrently), but callbacks for different connections can be safely executed in parallel.</p>
+<p><code><a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a></code> and related objects (<code><a class="el" href="classproton_1_1session.html" title="A container of senders and receivers. ">proton::session</a></code>, <code><a class="el" href="classproton_1_1sender.html" title="A channel for sending messages. ">proton::sender</a></code>, <code><a class="el" href="classproton_1_1receiver.html" title="A channel for receiving messages. ">proton::receiver</a></code>, <code><a class="el" href="classproton_1_1delivery.html" title="A received message. ">proton::delivery</a></code>) are <em>not</em> thread-safe and are subject to the following rules.</p>
 <ol type="1">
 <li>They can only be used from a <code><a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a></code> event callback called by Proton or a <code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> function (more below).</li>
 <li>You cannot use objects belonging to one connection from a callback for another connection. We recommend a single handler instance per connection to avoid confusion.</li>
 <li>You can store Proton objects in member variables for use in a later callback, provided you respect rule two.</li>
 </ol>
+<p><code><a class="el" href="classproton_1_1message.html" title="An AMQP message. ">proton::message</a></code> is a value type with the same threading constraints as a standard C++ built-in type. It cannot be concurrently modified.</p>
 <h2>Work queues</h2>
 <p><code><a class="el" href="classproton_1_1work__queue.html" title="Unsettled API - A context for thread-safe execution of work. ">proton::work_queue</a></code> provides a safe way to communicate between different connection handlers or between non-Proton threads and connection handlers.</p>
 <ul>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_8cpp-example.html
index d1f4f38..407b2cf 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/multithreaded_client_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('multithreaded_client_8cpp-example.html
 </div><!--header-->
 <div class="contents">
 <p>A multithreaded sender and receiver.<b>Requires C++11</b></p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// C++11 or greater</span></div><div class="line"><span class="comment">//</span></div><d
 iv class="line"><span class="comment">// A multi-threaded client that calls proton::container::run() in one thread, sends</span></div><div class="line"><span class="comment">// messages in another and receives messages in a third.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Note this client does not deal with flow-control. If the sender is faster</span></div><div class="line"><span class="comment">// than the receiver, messages will build up in memory on the sending side.</span></div><div class="line"><span class="comment">// See @ref multithreaded_client_flow_control.cpp for a more complex example with</span></div><div class="line"><span class="comment">// flow control.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// NOTE: no proper error handling</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver_8hpp.html">proton/receiver.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender_8hpp.html">proton/sender.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#inclu
 de &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;condition_variable&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;mutex&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;queue&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;sstream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line"></div><div class="line"><span class="comment">// Lock output from threads to avoid scramblin</span></div><div class="line">std::mutex out_lock;</div><div class="line"><span class="preprocessor">#define OUT(x) do { std::lock_guard&lt;std::mutex&gt; l(out_lock); x; } while (false)</
 span></div><div class="line"></div><div class="line"><span class="comment">// Handler for a single thread-safe sending and receiving connection.</span></div><div class="line"><span class="keyword">class </span>client : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="comment">// Invariant</span></div><div class="line">    <span class="keyword">const</span> std::string url_;</div><div class="line">    <span class="keyword">const</span> std::string address_;</div><div class="line"></div><div class="line">    <span class="comment">// Only used in proton handler thread</span></div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line"></div><div class="line">    <span class="comment">// Shared by proton and user threads, protected by lock_</span></div><div class="li
 ne">    std::mutex lock_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> *work_queue_;</div><div class="line">    std::condition_variable sender_ready_;</div><div class="line">    std::queue&lt;proton::message&gt; messages_;</div><div class="line">    std::condition_variable messages_ready_;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    client(<span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address) : url_(url), address_(address), work_queue_(0) {}</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> send(<span class="keyword">const</span> <a name="_a3"></a><a class="code" href="classproton_1_1message.html">proton::message</a>&amp; msg) {</div><div class="line">        <span cl
 ass="comment">// Use [=] to copy the message, we cannot pass it by reference since it</span></div><div class="line">        <span class="comment">// will be used in another thread.</span></div><div class="line">        work_queue()-&gt;<a name="a4"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { sender_.<a name="a5"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(msg); });</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <a class="code" href="classproton_1_1message.html">proton::message</a> receive() {</div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (messages_.empty()) messages_ready_.wait(l);</div><div class="line">        <span class="keyword">auto</span> msg = std::move(messa
 ges_.front());</div><div class="line">        messages_.pop();</div><div class="line">        <span class="keywordflow">return</span> msg;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        work_queue()-&gt;add([=]() { sender_.<a name="a6"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a7"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue() {</div><div class="line">        <span class="comment">// Wait till work_queue_ and sender_ ar
 e initialized.</span></div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (!work_queue_) sender_ready_.wait(l);</div><div class="line">        <span class="keywordflow">return</span> work_queue_;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// == messaging_handler overrides, only called in proton hander thread</span></div><div class="line"></div><div class="line">    <span class="comment">// Note: this example creates a connection when the container starts.</span></div><div class="line">    <span class="comment">// To create connections after the container has started, use</span></div><div class="line">    <span class="comment">// container::connect().</span></div><div class="line">    <span class="comment">// See @ref multithreaded_client_flow_control.cpp for an example.</span></div><div class="line">    <span class="keywordtype">voi
 d</span> <a name="a8"></a><a class="code" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a>(<a name="_a9"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont)<span class="keyword"> override </span>{</div><div class="line">        cont.<a name="a10"></a><a class="code" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1">connect</a>(url_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a11"></a><a class="code" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">on_connection_open</a>(<a name="_a12"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; conn)<span class="keyword"> override </span>{</div><div class="line">        conn.<a name="a13"></a><a class="code" href="classproton_1_1connection.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">open
 _sender</a>(address_);</div><div class="line">        conn.<a name="a14"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(address_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a15"></a><a class="code" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661">on_sender_open</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        <span class="comment">// sender_ and work_queue_ must be set atomically</span></div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        sender_ = s;</div><div class="line">        work_queue_ = &amp;s.<a name="a16"></a><a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">        sende
 r_ready_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a17"></a><a class="code" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a>(<a name="_a18"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a>&amp; dlv, <a class="code" href="classproton_1_1message.html">proton::message</a>&amp; msg)<span class="keyword"> override </span>{</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        messages_.push(msg);</div><div class="line">        messages_ready_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a19"></a><a class="code" href="classproton_1_1messaging__handler.html#a5e29fef3b8c5b8cf18aa7d69850ac22e">on_error</a>(<span class="keyword">const</span> <a name="_a20"></a><a class="code" h
 ref="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keyword">const</span> <span class="keywordtype">char</span>** argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        <span class="keywordflow">if</span> (argc != 4) {</div><div class="line">            std ::cerr &lt;&lt;</div><div class="line">                <span class="stringliteral">&quot;Usage: &quot;</span> &lt;&lt; argv[0] &lt;&lt; <span class="stringliteral">&quot; CONNECTION-URL AMQP-ADDRESS MESSAGE-COUNT\n&quot;</span></d
 iv><div class="line">                <span class="stringliteral">&quot;CONNECTION-URL: connection address, e.g.&#39;amqp://127.0.0.1&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;AMQP-ADDRESS: AMQP node address, e.g. &#39;examples&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;MESSAGE-COUNT: number of messages to send\n&quot;</span>;</div><div class="line">            <span class="keywordflow">return</span> 1;</div><div class="line">        }</div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *url = argv[1];</div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *address = argv[2];</div><div class="line">        <span class="keywordtype">int</span> n_messages = atoi(argv[3]);</div><div class="line"></div><div class="line">        client cl(url, address);</div><div class="line">        <a cla
 ss="code" href="classproton_1_1container.html">proton::container</a> container(cl);</div><div class="line">        std::thread container_thread([&amp;]() { container.<a name="a21"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>(); });</div><div class="line"></div><div class="line">        std::thread sender([&amp;]() {</div><div class="line">                <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_messages; ++i) {</div><div class="line">                    <a class="code" href="classproton_1_1message.html">proton::message</a> msg(<a name="a22"></a><a class="code" href="namespaceproton.html#a1367d11b0ac6a99ea8e7d9a5b8f36b34">std::to_string</a>(i + 1));</div><div class="line">                    cl.send(msg);</div><div class="line">                    OUT(std::cout &lt;&lt; <span class="stringliteral">&quot;sent \&quot;&quot;</span> &lt;&lt; msg.<a name="a23"></a><a class="code" href="
 classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">                }</div><div class="line">            });</div><div class="line"></div><div class="line">        <span class="keywordtype">int</span> received = 0;</div><div class="line">        std::thread receiver([&amp;]() {</div><div class="line">                <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_messages; ++i) {</div><div class="line">                    <span class="keyword">auto</span> msg = cl.receive();</div><div class="line">                    OUT(std::cout &lt;&lt; <span class="stringliteral">&quot;received \&quot;&quot;</span> &lt;&lt; msg.body() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">                    ++received;</div><div class="line">                }</div><div class="line">
             });</div><div class="line"></div><div class="line">        sender.join();</div><div class="line">        receiver.join();</div><div class="line">        cl.close();</div><div class="line">        container_thread.join();</div><div class="line">        std::cout &lt;&lt; received &lt;&lt; <span class="stringliteral">&quot; messages sent and received&quot;</span> &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// C++11 or greater</span></div><div class="line"><span class="comment">//</span></div><d
 iv class="line"><span class="comment">// A multi-threaded client that calls proton::container::run() in one thread, sends</span></div><div class="line"><span class="comment">// messages in another and receives messages in a third.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// Note this client does not deal with flow-control. If the sender is faster</span></div><div class="line"><span class="comment">// than the receiver, messages will build up in memory on the sending side.</span></div><div class="line"><span class="comment">// See @ref multithreaded_client_flow_control.cpp for a more complex example with</span></div><div class="line"><span class="comment">// flow control.</span></div><div class="line"><span class="comment">//</span></div><div class="line"><span class="comment">// NOTE: no proper error handling</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="connection__options_8hpp.html">proton/connection_options.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="receiver_8hpp.html">proton/receiver.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sender_8hpp.html">proton/sender.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#inclu
 de &lt;<a class="code" href="work__queue_8hpp.html">proton/work_queue.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;condition_variable&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;mutex&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;queue&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;sstream&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;thread&gt;</span></div><div class="line"></div><div class="line"><span class="comment">// Lock output from threads to avoid scrambling</span></div><div class="line">std::mutex out_lock;</div><div class="line"><span class="preprocessor">#define OUT(x) do { std::lock_guard&lt;std::mutex&gt; l(out_lock); x; } while (false)<
 /span></div><div class="line"></div><div class="line"><span class="comment">// Handler for a single thread-safe sending and receiving connection.</span></div><div class="line"><span class="keyword">class </span>client : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    <span class="comment">// Invariant</span></div><div class="line">    <span class="keyword">const</span> std::string url_;</div><div class="line">    <span class="keyword">const</span> std::string address_;</div><div class="line"></div><div class="line">    <span class="comment">// Only used in proton handler thread</span></div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> sender_;</div><div class="line"></div><div class="line">    <span class="comment">// Shared by proton and user threads, protected by lock_</span></div><div class="l
 ine">    std::mutex lock_;</div><div class="line">    <a name="_a2"></a><a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a> *work_queue_;</div><div class="line">    std::condition_variable sender_ready_;</div><div class="line">    std::queue&lt;proton::message&gt; messages_;</div><div class="line">    std::condition_variable messages_ready_;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    client(<span class="keyword">const</span> std::string&amp; url, <span class="keyword">const</span> std::string&amp; address) : url_(url), address_(address), work_queue_(0) {}</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> send(<span class="keyword">const</span> <a name="_a3"></a><a class="code" href="classproton_1_1message.html">proton::message</a>&amp; msg) {</div><div class="line">        <span c
 lass="comment">// Use [=] to copy the message, we cannot pass it by reference since it</span></div><div class="line">        <span class="comment">// will be used in another thread.</span></div><div class="line">        work_queue()-&gt;<a name="a4"></a><a class="code" href="classproton_1_1work__queue.html#a59dae2153455bc095477a3b66a0b681e">add</a>([=]() { sender_.<a name="a5"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(msg); });</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <a class="code" href="classproton_1_1message.html">proton::message</a> receive() {</div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (messages_.empty()) messages_ready_.wait(l);</div><div class="line">        <span class="keyword">auto</span> msg = std::move(mess
 ages_.front());</div><div class="line">        messages_.pop();</div><div class="line">        <span class="keywordflow">return</span> msg;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// Thread safe</span></div><div class="line">    <span class="keywordtype">void</span> close() {</div><div class="line">        work_queue()-&gt;add([=]() { sender_.<a name="a6"></a><a class="code" href="classproton_1_1link.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a7"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>(); });</div><div class="line">    }</div><div class="line"></div><div class="line">  <span class="keyword">private</span>:</div><div class="line"></div><div class="line">    <a class="code" href="classproton_1_1work__queue.html">proton::work_queue</a>* work_queue() {</div><div class="line">        <span class="comment">// Wait till work_queue_ and sender_ a
 re initialized.</span></div><div class="line">        std::unique_lock&lt;std::mutex&gt; l(lock_);</div><div class="line">        <span class="keywordflow">while</span> (!work_queue_) sender_ready_.wait(l);</div><div class="line">        <span class="keywordflow">return</span> work_queue_;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="comment">// == messaging_handler overrides, only called in proton handler thread</span></div><div class="line"></div><div class="line">    <span class="comment">// Note: this example creates a connection when the container starts.</span></div><div class="line">    <span class="comment">// To create connections after the container has started, use</span></div><div class="line">    <span class="comment">// container::connect().</span></div><div class="line">    <span class="comment">// See @ref multithreaded_client_flow_control.cpp for an example.</span></div><div class="line">    <span class="keywordtype">v
 oid</span> <a name="a8"></a><a class="code" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">on_container_start</a>(<a name="_a9"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; cont)<span class="keyword"> override </span>{</div><div class="line">        cont.<a name="a10"></a><a class="code" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1">connect</a>(url_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a11"></a><a class="code" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">on_connection_open</a>(<a name="_a12"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; conn)<span class="keyword"> override </span>{</div><div class="line">        conn.<a name="a13"></a><a class="code" href="classproton_1_1connection.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">op
 en_sender</a>(address_);</div><div class="line">        conn.<a name="a14"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(address_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a15"></a><a class="code" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4">on_sender_open</a>(<a class="code" href="classproton_1_1sender.html">proton::sender</a>&amp; s)<span class="keyword"> override </span>{</div><div class="line">        <span class="comment">// sender_ and work_queue_ must be set atomically</span></div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        sender_ = s;</div><div class="line">        work_queue_ = &amp;s.<a name="a16"></a><a class="code" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">work_queue</a>();</div><div class="line">        sen
 der_ready_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a17"></a><a class="code" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">on_message</a>(<a name="_a18"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a>&amp; dlv, <a class="code" href="classproton_1_1message.html">proton::message</a>&amp; msg)<span class="keyword"> override </span>{</div><div class="line">        std::lock_guard&lt;std::mutex&gt; l(lock_);</div><div class="line">        messages_.push(msg);</div><div class="line">        messages_ready_.notify_all();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a19"></a><a class="code" href="classproton_1_1messaging__handler.html#a042f595d1807eb1abe0195ab79357edd">on_error</a>(<span class="keyword">const</span> <a name="_a20"></a><a class="code"
  href="classproton_1_1error__condition.html">proton::error_condition</a>&amp; e)<span class="keyword"> override </span>{</div><div class="line">        OUT(std::cerr &lt;&lt; <span class="stringliteral">&quot;unexpected error: &quot;</span> &lt;&lt; e &lt;&lt; std::endl);</div><div class="line">        exit(1);</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keyword">const</span> <span class="keywordtype">char</span>** argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        <span class="keywordflow">if</span> (argc != 4) {</div><div class="line">            std ::cerr &lt;&lt;</div><div class="line">                <span class="stringliteral">&quot;Usage: &quot;</span> &lt;&lt; argv[0] &lt;&lt; <span class="stringliteral">&quot; CONNECTION-URL AMQP-ADDRESS MESSAGE-COUNT\n&quot;</span><
 /div><div class="line">                <span class="stringliteral">&quot;CONNECTION-URL: connection address, e.g.&#39;amqp://127.0.0.1&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;AMQP-ADDRESS: AMQP node address, e.g. &#39;examples&#39;\n&quot;</span></div><div class="line">                <span class="stringliteral">&quot;MESSAGE-COUNT: number of messages to send\n&quot;</span>;</div><div class="line">            <span class="keywordflow">return</span> 1;</div><div class="line">        }</div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *url = argv[1];</div><div class="line">        <span class="keyword">const</span> <span class="keywordtype">char</span> *address = argv[2];</div><div class="line">        <span class="keywordtype">int</span> n_messages = atoi(argv[3]);</div><div class="line"></div><div class="line">        client cl(url, address);</div><div class="line">        <a c
 lass="code" href="classproton_1_1container.html">proton::container</a> container(cl);</div><div class="line">        std::thread container_thread([&amp;]() { container.<a name="a21"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>(); });</div><div class="line"></div><div class="line">        std::thread sender([&amp;]() {</div><div class="line">                <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_messages; ++i) {</div><div class="line">                    <a class="code" href="classproton_1_1message.html">proton::message</a> msg(<a name="a22"></a><a class="code" href="namespaceproton.html#a1367d11b0ac6a99ea8e7d9a5b8f36b34">std::to_string</a>(i + 1));</div><div class="line">                    cl.send(msg);</div><div class="line">                    OUT(std::cout &lt;&lt; <span class="stringliteral">&quot;sent \&quot;&quot;</span> &lt;&lt; msg.<a name="a23"></a><a class="code" href
 ="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">                }</div><div class="line">            });</div><div class="line"></div><div class="line">        <span class="keywordtype">int</span> received = 0;</div><div class="line">        std::thread receiver([&amp;]() {</div><div class="line">                <span class="keywordflow">for</span> (<span class="keywordtype">int</span> i = 0; i &lt; n_messages; ++i) {</div><div class="line">                    <span class="keyword">auto</span> msg = cl.receive();</div><div class="line">                    OUT(std::cout &lt;&lt; <span class="stringliteral">&quot;received \&quot;&quot;</span> &lt;&lt; msg.body() &lt;&lt; <span class="charliteral">&#39;&quot;&#39;</span> &lt;&lt; std::endl);</div><div class="line">                    ++received;</div><div class="line">                }</div><div class="line
 ">            });</div><div class="line"></div><div class="line">        sender.join();</div><div class="line">        receiver.join();</div><div class="line">        cl.close();</div><div class="line">        container_thread.join();</div><div class="line">        std::cout &lt;&lt; received &lt;&lt; <span class="stringliteral">&quot; messages sent and received&quot;</span> &lt;&lt; std::endl;</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->


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


[28/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/sasl-plugin_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/sasl-plugin_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/sasl-plugin_8h_source.html
index 8738f18..0d83235 100755
--- a/content/releases/qpid-proton-master/proton/c/api/sasl-plugin_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/sasl-plugin_8h_source.html
@@ -93,9 +93,9 @@ $(document).ready(function(){initNavTree('sasl-plugin_8h_source.html','');});
 <div class="title">sasl-plugin.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SASL_PLUGIN_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SASL_PLUGIN_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"
 ><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014
 "></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="l
 ineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;
 <a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="comment">// Internal SASL authenticator interface: These are the entry points to a SASL implementations</span></div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">//</span></div><div 
 class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="comment">// Free up all data structures allocated by the SASL implementation</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="comment">// void free(pn_transport_t *transport);</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="comment">// Return space separated list of supported mechanisms (client and server)</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="comment">// If the returned string is dynamically allocated by the SASL implemetation</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="comment">// it must stay valid until the free entry point is called.</span></div><div c
 lass="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="comment">// const char *list_mechs(pn_transport_t *transport);</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="comment">// Initialise for either client or server (can&#39;t call both for a</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="comment">// given transport/connection):</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="comment">// bool init_server(pn_transport_t *transport);</span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="comment">// bool init_client(pn_transport_t *transport);</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160
 ;<span class="comment">//</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="comment">// Writing:</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="comment">// void prepare_write(pn_transport_t *transport);</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment">// Reading:</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="comment">// Server side (process server SASL messages):</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="comment">// void process_init(pn_transport_t *transport, const char *mechanism, const pn_bytes_t *recv);</span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</
 span>&#160;<span class="comment">// void process_response(pn_transport_t *transport, const pn_bytes_t *recv);</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="comment">//</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="comment">// Client side (process client SASL messages)</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="comment">// bool process_mechanisms(pn_transport_t *transport, const char *mechs);</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="comment">// void process_challenge(pn_transport_t *transport, const pn_bytes_t *recv);</span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="comment">// void process_outcome(pn_transport_t *transport);</span></div><div class="line"><a name="l00060"></a><span class="lineno">  
  60</span>&#160;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="comment">// Security layer interface (active after SASL succeeds)</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="comment">// bool    can_encrypt(pn_transport_t *transport);</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="comment">// ssize_t max_encrypt_size(pn_transport_t *transport);</span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="comment">// ssize_t encode(pn_transport_t *transport, pn_bytes_t in, pn_bytes_t *out);</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="comment">// ssize_t decode(pn_transport_t *transport, pn_bytes_t in, pn_bytes_t *out);</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class=
 "line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pnx_sasl_implementation</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;{</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;    void (*free)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;    <span class="keyword">const</span> <span class="keywordtype">char</span>*  (*list_mechs)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#1
 60;    bool (*init_server)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    bool (*init_client)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    void (*prepare_write)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;    void (*process_init)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</sp
 an> <span class="keywordtype">char</span> *mechanism, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    void (*process_response)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    bool (*process_mechanisms)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechs);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;
     void (*process_challenge)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    void (*process_outcome)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    bool    (*can_encrypt)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    ssize_t (*max_encrypt_size)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transp
 ort_t</a> *transport);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    ssize_t (*encode)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> in, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *out);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    ssize_t (*decode)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> in, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *out);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;} pnx_sasl_implementation;</div><
 div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;<span class="comment">// Shared SASL API used by the actual SASL authenticators</span></div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;<span class="keyword">enum</span> pnx_sasl_state {</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;  SASL_NONE,</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;  SASL_POSTED_INIT,</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;  SASL_POSTED_MECHANISMS,</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;  SASL_POSTED_RESPONSE,</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;  SASL_POSTED_CHALLENGE,</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;  SASL_RE
 CVED_OUTCOME_SUCCEED,</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;  SASL_RECVED_OUTCOME_FAIL,</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;  SASL_POSTED_OUTCOME,</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;  SASL_ERROR</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;};</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;<span class="comment">// APIs used by sasl implementations</span></div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_logf(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, ...)
 ;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pnx_sasl_get_context(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_context(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_client(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a>
  *transport);</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_included_mech(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> s);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_transport_encrypted(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_get_allow_insecure_mechs(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span
 >&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_get_auth_required(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_external_username(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PN_EXTERN <span class="keywordtype">int</span>   pnx_sasl_get_external_ssf(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PN_EXTERN <span class="keyword">const</span> <span clas
 s="keywordtype">char</span> *pnx_sasl_get_username(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_password(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_clear_password(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_remote_fqdn(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d
 12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_selected_mechanism(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_bytes_out(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> bytes);</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_desired_state(<a class="code" href="group__transport.html#gac26e
 da05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">enum</span> pnx_sasl_state desired_state);</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_selected_mechanism(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechanism);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_local_hostname(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> * transport, <span class="keyword">const</span> <span class="keywordtype">char</span> * fqdn);</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_succeed_authent
 ication(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *username);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_fail_authentication(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_implementation(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> pnx_sasl_implementation *impl, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00133"></a><span 
 class="lineno">  133</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_default_implementation(<span class="keyword">const</span> pnx_sasl_implementation *impl);</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;}</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* sasl-plugin.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h
 </a></div><div class="ttdoc">AMQP and API data types. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">An AMQP Transport object. </div><div class="ttdef"><b>Definition:</b> types.h:421</div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:202</div></div>
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SASL_PLUGIN_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SASL_PLUGIN_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"
 ><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014
 "></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="l
 ineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;
 <a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="comment">  Internal SASL authenticator interface: These are the entry points to a SASL implementations</span></div><div c
 lass="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="comment">  Free up all data structures allocated by the SASL implementation</span></div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="comment">  void free(pn_transport_t *transport);</span></div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="comment">  Return space separated list of supported mechanisms (client and server)</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="comment">  If the returned string is dynamically allocated by the SASL implemetation</span></div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>
 &#160;<span class="comment">  it must stay valid until the free entry point is called.</span></div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="comment">  const char *list_mechs(pn_transport_t *transport);</span></div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="comment">  Initialise for either client or server (can&#39;t call both for a</span></div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="comment">  given transport/connection):</span></div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="comment">  bool init_server(pn_transport_t *transport);</span></div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="comment">  bool init_client(pn_transport_t *tra
 nsport);</span></div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="comment">  Writing:</span></div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="comment">  void prepare_write(pn_transport_t *transport);</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="comment">  Reading:</span></div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="comment">  Server side (process server SASL messages):</span></div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="comment">  void process_init(pn_transport_t *transport, const char *mechanism, const pn_bytes_
 t *recv);</span></div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="comment">  void process_response(pn_transport_t *transport, const pn_bytes_t *recv);</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="comment">  Client side (process client SASL messages)</span></div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="comment">  bool process_mechanisms(pn_transport_t *transport, const char *mechs);</span></div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="comment">  void process_challenge(pn_transport_t *transport, const pn_bytes_t *recv);</span></div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="comment">  void process_outcome(pn_transport_t *tran
 sport);</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;<span class="comment"></span></div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="comment">  Security layer interface (active after SASL succeeds)</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="comment">  bool    can_encrypt(pn_transport_t *transport);</span></div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="comment">  ssize_t max_encrypt_size(pn_transport_t *transport);</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="comment">  ssize_t encode(pn_transport_t *transport, pn_bytes_t in, pn_bytes_t *out);</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="comment">  ssize_t decode(pn_transport_t *transport, pn_bytes_t in, pn_bytes_t *out);</
 span></div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="comment">*/</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span>pnx_sasl_implementation</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;{</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;    void (*free)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;    <span class="keyword">const</span> <span class="keywordtype">char</span>*  (*list_mechs)(<a class="code" href="group__transport.html#gac26eda05f
 649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;    bool (*init_server)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;    bool (*init_client)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;    void (*prepare_write)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a nam
 e="l00082"></a><span class="lineno">   82</span>&#160;    void (*process_init)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechanism, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;    void (*process_response)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00084"></a><span class="lineno">   84</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    bool (*process_mechanisms)(<a class="code" href="group__transport.html#gac26eda05f
 649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechs);</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;    void (*process_challenge)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *recv);</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    void (*process_outcome)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;    bool    (*can_encrypt)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t<
 /a> *transport);</div><div class="line"><a name="l00090"></a><span class="lineno">   90</span>&#160;    ssize_t (*max_encrypt_size)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    ssize_t (*encode)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> in, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> *out);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;    ssize_t (*decode)(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> in, <a class="code" href="group__api__types.html#structpn__bytes__t">p
 n_bytes_t</a> *out);</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;} pnx_sasl_implementation;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;<span class="comment">/* Shared SASL API used by the actual SASL authenticators */</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;<span class="keyword">enum</span> pnx_sasl_state {</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;  SASL_NONE,</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;  SASL_POSTED_INIT,</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;  SASL_POSTED_MECHANISMS,</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;
   SASL_POSTED_RESPONSE,</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;  SASL_POSTED_CHALLENGE,</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;  SASL_RECVED_OUTCOME_SUCCEED,</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;  SASL_RECVED_OUTCOME_FAIL,</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;  SASL_POSTED_OUTCOME,</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;  SASL_ERROR</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;};</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;<span class="comment">/* APIs used by sasl implementations */</span></div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN <span class="keywordtyp
 e">void</span>  pnx_sasl_logf(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *format, ...);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *pnx_sasl_get_context(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_context(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00114"></a><span class="lineno">  114</span>&#160;</div><div class="line"
 ><a name="l00115"></a><span class="lineno">  115</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_client(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_included_mech(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> s);</div><div class="line"><a name="l00117"></a><span class="lineno">  117</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_is_transport_encrypted(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PN_EXTERN <span class="keywordtype">bool</sp
 an>  pnx_sasl_get_allow_insecure_mechs(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PN_EXTERN <span class="keywordtype">bool</span>  pnx_sasl_get_auth_required(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_external_username(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;PN_EXTERN <span class="keywordtype">int</span>   pnx_sasl_get_external_ssf(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transpo
 rt);</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_username(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_password(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_clear_password(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00126
 "></a><span class="lineno">  126</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_remote_fqdn(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *pnx_sasl_get_selected_mechanism(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_bytes_out(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="code" href="group__api__types.html#structpn__bytes__t">pn_by
 tes_t</a> bytes);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_desired_state(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">enum</span> pnx_sasl_state desired_state);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_selected_mechanism(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechanism);</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_local_hostname(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> * transport, <span class
 ="keyword">const</span> <span class="keywordtype">char</span> * fqdn);</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_succeed_authentication(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> <span class="keywordtype">char</span> *username);</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_fail_authentication(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_implementation(<a class="code" href="group__transport.html#gac26
 eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <span class="keyword">const</span> pnx_sasl_implementation *impl, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;PN_EXTERN <span class="keywordtype">void</span>  pnx_sasl_set_default_implementation(<span class="keyword">const</span> pnx_sasl_implementation *impl);</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;}</div><div class="line"><a name="l00143"></a><span class="lineno">  143</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</
 span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* sasl-plugin.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/sasl_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/sasl_8h.html b/content/releases/qpid-proton-master/proton/c/api/sasl_8h.html
index c5a4bd7..eed1a0b 100755
--- a/content/releases/qpid-proton-master/proton/c/api/sasl_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/sasl_8h.html
@@ -138,8 +138,9 @@ Functions</h2></td></tr>
 <tr class="memitem:ga0199871440c4ff89a204cc1d8a09f283"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283">pn_sasl_done</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a> outcome)</td></tr>
 <tr class="memdesc:ga0199871440c4ff89a204cc1d8a09f283"><td class="mdescLeft">&#160;</td><td class="mdescRight">Set the outcome of SASL negotiation.  <a href="group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283">More...</a><br /></td></tr>
 <tr class="separator:ga0199871440c4ff89a204cc1d8a09f283"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
-<tr class="memdesc:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the outcome of SASL negotiation.  <a href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">More...</a><br /></td></tr>
+<tr class="memitem:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memItemLeft" align="right" valign="top">
+<a class="el" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
+<tr class="memdesc:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the outcome of SASL negotiation. <br /></td></tr>
 <tr class="separator:ga03b6daf742db6a07bd7d03cb197aedb6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga700e1d505068f895383dd932af55987e"><td class="memItemLeft" align="right" valign="top">const char *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__sasl.html#ga700e1d505068f895383dd932af55987e">pn_sasl_get_user</a> (<a class="el" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl)</td></tr>
 <tr class="memdesc:ga700e1d505068f895383dd932af55987e"><td class="mdescLeft">&#160;</td><td class="mdescRight">Retrieve the authenticated user.  <a href="group__sasl.html#ga700e1d505068f895383dd932af55987e">More...</a><br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/sasl_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/sasl_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/sasl_8h_source.html
index b61b3f6..ed5ff37 100755
--- a/content/releases/qpid-proton-master/proton/c/api/sasl_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/sasl_8h_source.html
@@ -93,9 +93,9 @@ $(document).ready(function(){initNavTree('sasl_8h_source.html','');});
 <div class="title">sasl.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="sasl_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SASL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SASL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements. 
  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment
 "> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><di
 v class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</s
 pan>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">   49</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__sasl.html#ga4d21fd
 dba80d3f88d0529aafe12328b0">pn_sasl_t</a> <a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a>;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">   54</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  PN_SASL_NONE = -1,  </div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e">   56</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e">PN_SASL_OK</a> = 0,     </div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad
 44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a">   57</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a">PN_SASL_AUTH</a> = 1,   </div><div class="line"><a name="l00058"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939">   58</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939">PN_SASL_SYS</a> = 2,    </div><div class="line"><a name="l00059"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191">   59</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191">PN_SASL_PERM</a> = 3,   </div><div class="line"><a name="l00060"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad4
 4e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3">   60</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3">PN_SASL_TEMP</a> = 4    </div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;} <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;PN_EXTERN <a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *<a class="code" href="group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c">pn_sasl</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00088"><
 /a><span class="lineno">   88</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__sasl.html#ga1737191972d5dded0993bf1431e71df0">pn_sasl_extended</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283">pn_sasl_done</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a> outcome);</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;PN_EXTERN <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_o
 utcome_t</a> <a class="code" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__sasl.html#ga700e1d505068f895383dd932af55987e">pn_sasl_get_user</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863">pn_sasl_get_mech</a>(<
 a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#ga73299a6a22e141e7911a739590032625">pn_sasl_allowed_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechs);</div><div class="line"><a name="l00146"></a><span class="lineno">  146</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315">pn_sasl_set_allow_insecure_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sa
 sl_t</a> *sasl, <span class="keywordtype">bool</span> insecure);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243">pn_sasl_get_allow_insecure_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56">pn_sasl_config_name</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="
 line"><a name="l00186"></a><span class="lineno">  186</span>&#160;</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gabf4176414424ce02a4e03b4338d30521">pn_sasl_config_path</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *path);</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;}</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div 
 class="line"><a name="l00212"></a><span class="lineno">  212</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* sasl.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<a href="sasl_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SASL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SASL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements. 
  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment
 "> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><di
 v class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</s
 pan>&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">   49</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__sasl.html#ga4d21fd
 dba80d3f88d0529aafe12328b0">pn_sasl_t</a> <a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a>;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">   54</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  PN_SASL_NONE = -1,  </div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e">   56</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba0050b91650a3826a090e13f57b3b941e">PN_SASL_OK</a> = 0,     </div><div class="line"><a name="l00057"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad
 44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a">   57</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bac63734ecde7c8170554f6bf04f6ce64a">PN_SASL_AUTH</a> = 1,   </div><div class="line"><a name="l00058"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939">   58</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939">PN_SASL_SYS</a> = 2,    </div><div class="line"><a name="l00059"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191">   59</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3ba03019f909ba1d98aae94437ca4bd0191">PN_SASL_PERM</a> = 3,   </div><div class="line"><a name="l00060"></a><span class="lineno"><a class="line" href="group__sasl.html#ggad4
 4e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3">   60</a></span>&#160;  <a class="code" href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3baee28d2c03fa80dccf771e37aae1bcdf3">PN_SASL_TEMP</a> = 4    </div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;} <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a>;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;PN_EXTERN <a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *<a class="code" href="group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c">pn_sasl</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;</div><div class="line"><a name="l00088"><
 /a><span class="lineno">   88</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__sasl.html#ga1737191972d5dded0993bf1431e71df0">pn_sasl_extended</a>(<span class="keywordtype">void</span>);</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#ga0199871440c4ff89a204cc1d8a09f283">pn_sasl_done</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_outcome_t</a> outcome);</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;PN_EXTERN <a class="code" href="group__sasl.html#gad44e79f52e0669b1930689b56dfa9c3b">pn_sasl_o
 utcome_t</a> <a class="code" href="group__sasl.html#ga03b6daf742db6a07bd7d03cb197aedb6">pn_sasl_outcome</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__sasl.html#ga700e1d505068f895383dd932af55987e">pn_sasl_get_user</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span> *<a class="code" href="group__sasl.html#ga895b6a957bf0c0204aaddb3ec5b9d863">pn_sasl_get_mech</a>(<
 a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno">  141</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#ga73299a6a22e141e7911a739590032625">pn_sasl_allowed_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *mechs);</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315">pn_sasl_set_allow_insecure_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sa
 sl_t</a> *sasl, <span class="keywordtype">bool</span> insecure);</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__sasl.html#gac53ad15ee429b7ce9d0c598d1e347243">pn_sasl_get_allow_insecure_mechs</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl);</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00181"></a><span class="lineno">  181</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gad1a6932135165f0e5b7639b79ac71c56">pn_sasl_config_name</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *name);</div><div class="
 line"><a name="l00182"></a><span class="lineno">  182</span>&#160;</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__sasl.html#gabf4176414424ce02a4e03b4338d30521">pn_sasl_config_path</a>(<a class="code" href="group__sasl.html#ga4d21fddba80d3f88d0529aafe12328b0">pn_sasl_t</a> *sasl, <span class="keyword">const</span> <span class="keywordtype">char</span> *path);</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;}</div><div class="line"><a name="l00206"></a><span class="lineno">  206</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00207"></a><span class="lineno">  207</span>&#160;</div><div 
 class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* sasl.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
 <div class="ttc" id="group__sasl_html_ga73299a6a22e141e7911a739590032625"><div class="ttname"><a href="group__sasl.html#ga73299a6a22e141e7911a739590032625">pn_sasl_allowed_mechs</a></div><div class="ttdeci">void pn_sasl_allowed_mechs(pn_sasl_t *sasl, const char *mechs)</div><div class="ttdoc">SASL mechanisms that are to be considered for authentication. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__sasl_html_ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939"><div class="ttname"><a href="group__sasl.html#ggad44e79f52e0669b1930689b56dfa9c3bacd46a2fda23f674c23ed81e6076c1939">PN_SASL_SYS</a></div><div class="ttdoc">failed due to bad credentials </div><div class="ttdef"><b>Definition:</b> sasl.h:58</div></div>
 <div class="ttc" id="group__sasl_html_ga7968e80e2fe9360fc14cf865dd1ac21c"><div class="ttname"><a href="group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c">pn_sasl</a></div><div class="ttdeci">pn_sasl_t * pn_sasl(pn_transport_t *transport)</div><div class="ttdoc">Construct an Authentication and Security Layer object. </div></div>
 <div class="ttc" id="group__sasl_html_gaf472325bc055bb18a5a6f5ca03eda315"><div class="ttname"><a href="group__sasl.html#gaf472325bc055bb18a5a6f5ca03eda315">pn_sasl_set_allow_insecure_mechs</a></div><div class="ttdeci">void pn_sasl_set_allow_insecure_mechs(pn_sasl_t *sasl, bool insecure)</div><div class="ttdoc">Boolean to allow use of clear text authentication mechanisms. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/search/all_2.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/search/all_2.js b/content/releases/qpid-proton-master/proton/c/api/search/all_2.js
index 8545952..c337d55 100755
--- a/content/releases/qpid-proton-master/proton/c/api/search/all_2.js
+++ b/content/releases/qpid-proton-master/proton/c/api/search/all_2.js
@@ -3,5 +3,6 @@ var searchData=
   ['data',['Data',['../group__data.html',1,'']]],
   ['delivery',['Delivery',['../group__delivery.html',1,'']]],
   ['delivery_2eh',['delivery.h',['../delivery_8h.html',1,'']]],
+  ['deprecated_20list',['Deprecated List',['../deprecated.html',1,'']]],
   ['disposition_2eh',['disposition.h',['../disposition_8h.html',1,'']]]
 ];


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


[25/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/ssl_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/ssl_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/ssl_8h_source.html
index 18f5e76..bc5d41f 100755
--- a/content/releases/qpid-proton-master/proton/c/api/ssl_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/ssl_8h_source.html
@@ -93,16 +93,16 @@ $(document).ready(function(){initNavTree('ssl_8h_source.html','');});
 <div class="title">ssl.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="ssl_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SSL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SSL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  Se
 e the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> 
 *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div c
 lass="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span
 >&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno"><a class="line" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">   80</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__ssl.html#gaba83c3a1779
 c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a>;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno"><a class="line" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">   85</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> <a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a>;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno"><a class="line" href="group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225">   90</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00091"></a><spa
 n class="lineno"><a class="line" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c">   91</a></span>&#160;  <a class="code" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c">PN_SSL_MODE_CLIENT</a> = 1, </div><div class="line"><a name="l00092"></a><span class="lineno"><a class="line" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078">   92</a></span>&#160;  <a class="code" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078">PN_SSL_MODE_SERVER</a>      </div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;} <a class="code" href="group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225">pn_ssl_mode_t</a>;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00098"></a><span class="lineno"><a class="line" href="group__ssl.html#gaf175c116d5
 2a91001f9a3559b580f56d">   98</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00099"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d">   99</a></span>&#160;  <a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d">PN_SSL_RESUME_UNKNOWN</a>,        </div><div class="line"><a name="l00100"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f">  100</a></span>&#160;  <a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f">PN_SSL_RESUME_NEW</a>,            </div><div class="line"><a name="l00101"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d">  101</a></span>&#160;  <
 a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d">PN_SSL_RESUME_REUSED</a>          </div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;} <a class="code" href="group__ssl.html#gaf175c116d52a91001f9a3559b580f56d">pn_ssl_resume_status_t</a>;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb">pn_ssl_present</a>( <span class="keywordtype">void</span> );</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PN_EXTERN <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *<a class="code" href="group__ssl.html#gaab5e86
 b7a4d22943eba82c6e94b82357">pn_ssl_domain</a>(pn_ssl_mode_t mode);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d">pn_ssl_domain_free</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN <span class="keywordtype">int</span>  <a class="code" href="group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa">pn_ssl_domain_set_credentials</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;     
                                        <span class="keyword">const</span> <span class="keywordtype">char</span> *credential_1,</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;                                            <span class="keyword">const</span> <span class="keywordtype">char</span> *credential_2,</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;                                            <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d">pn_ssl_domain_set_trusted_ca_db</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class=
 "line"><a name="l00177"></a><span class="lineno">  177</span>&#160;                                <span class="keyword">const</span> <span class="keywordtype">char</span> *certificate_db);</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno"><a class="line" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">  195</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00196"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc">  196</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc">PN_SSL_VERIFY_NULL</a> = 0,   </div><div class="line"><a name="l00197"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95
 760c63d0b9685d4d44">  197</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44">PN_SSL_VERIFY_PEER</a>,       </div><div class="line"><a name="l00198"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5">  198</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5">PN_SSL_ANONYMOUS_PEER</a>,    </div><div class="line"><a name="l00199"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36">  199</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36">PN_SSL_VERIFY_PEER_NAME</a>   </div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;} <a class="code" href="group__ssl.html#gae5e33024ed6af3432
 d4c76d1484d7ecb">pn_ssl_verify_mode_t</a>;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">pn_ssl_domain_set_peer_authentication</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;                                                    <span class="keyword">const</span> pn_ssl_verify_mode_t mode,</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;                                                    <span class="keyword">const</span> <span class="keywordtype">char</span> *trusted_CAs);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="
 line"><a name="l00239"></a><span class="lineno">  239</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">pn_ssl_domain_allow_unsecured_client</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00240"></a><span class="lineno">  240</span>&#160;</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;PN_EXTERN <a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *<a class="code" href="group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c">pn_ssl</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;PN_EXTERN <span class="keywordtype">
 int</span> <a class="code" href="group__ssl.html#ga45f319dd31ad456b8a85927888f94acf">pn_ssl_init</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl,</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;                          <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;                          <span class="keyword">const</span> <span class="keywordtype">char</span> *session_id);</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52">pn_ssl_get_cipher_name</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ss
 l_t</a> *ssl, <span class="keywordtype">char</span> *buffer, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d">pn_ssl_get_ssf</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;</div><div class="line"><a name="l00306"></a><span class="lineno">  306</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#ga03e8070271747c3901d8d6e5710c0066">pn_ssl_get_protocol_name</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keywordtype">char</span> *buffer, <span class="keywordtype">size
 _t</span> size);</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;PN_EXTERN pn_ssl_resume_status_t <a class="code" href="group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f">pn_ssl_resume_status</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;</div><div class="line"><a name="l00345"></a><span class="lineno">  345</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a">pn_ssl_set_peer_hostname</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keyword">const</span> <span class="keywordtype">char</span> *hostname);</div><div class="line"><a name="l00346"></a><span class="lineno">  346</span>&#160;</div><di
 v class="line"><a name="l00360"></a><span class="lineno">  360</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga76636a5ce4696284356321226ee0731c">pn_ssl_get_peer_hostname</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keywordtype">char</span> *hostname, <span class="keywordtype">size_t</span> *bufsize);</div><div class="line"><a name="l00361"></a><span class="lineno">  361</span>&#160;</div><div class="line"><a name="l00369"></a><span class="lineno">  369</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span>* <a class="code" href="group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3">pn_ssl_get_remote_subject</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00370"></a><span class="lineno">  370</span>&#160;</div><div class="line"><a name="l00374"></a><s
 pan class="lineno"><a class="line" href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">  374</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00375"></a><span class="lineno">  375</span>&#160;  PN_SSL_CERT_SUBJECT_COUNTRY_NAME,</div><div class="line"><a name="l00376"></a><span class="lineno">  376</span>&#160;  PN_SSL_CERT_SUBJECT_STATE_OR_PROVINCE,</div><div class="line"><a name="l00377"></a><span class="lineno">  377</span>&#160;  PN_SSL_CERT_SUBJECT_CITY_OR_LOCALITY,</div><div class="line"><a name="l00378"></a><span class="lineno">  378</span>&#160;  PN_SSL_CERT_SUBJECT_ORGANIZATION_NAME,</div><div class="line"><a name="l00379"></a><span class="lineno">  379</span>&#160;  PN_SSL_CERT_SUBJECT_ORGANIZATION_UNIT,</div><div class="line"><a name="l00380"></a><span class="lineno">  380</span>&#160;  PN_SSL_CERT_SUBJECT_COMMON_NAME</div><div class="line"><a name="l00381"></a><span class="lineno">  381</span>&
 #160;} <a class="code" href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">pn_ssl_cert_subject_subfield</a>;</div><div class="line"><a name="l00382"></a><span class="lineno">  382</span>&#160;</div><div class="line"><a name="l00386"></a><span class="lineno"><a class="line" href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">  386</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00387"></a><span class="lineno">  387</span>&#160;  PN_SSL_SHA1,   <span class="comment">/* Produces hash that is 20 bytes long */</span></div><div class="line"><a name="l00388"></a><span class="lineno">  388</span>&#160;  PN_SSL_SHA256, <span class="comment">/* Produces hash that is 32 bytes long */</span></div><div class="line"><a name="l00389"></a><span class="lineno">  389</span>&#160;  PN_SSL_SHA512, <span class="comment">/* Produces hash that is 64 bytes long */</span></div><div class="line"><a name="l00390"></a><span c
 lass="lineno">  390</span>&#160;  PN_SSL_MD5     <span class="comment">/* Produces hash that is 16 bytes long */</span></div><div class="line"><a name="l00391"></a><span class="lineno">  391</span>&#160;} <a class="code" href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">pn_ssl_hash_alg</a>;</div><div class="line"><a name="l00392"></a><span class="lineno">  392</span>&#160;</div><div class="line"><a name="l00406"></a><span class="lineno">  406</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga324db5da83b1abad2e948481d65119d4">pn_ssl_get_cert_fingerprint</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl0,</div><div class="line"><a name="l00407"></a><span class="lineno">  407</span>&#160;                                          <span class="keywordtype">char</span> *fingerprint,</div><div class="line"><a name="l00408"></a><span class="lineno">  408</span>&#160;                       
                    <span class="keywordtype">size_t</span> fingerprint_length,</div><div class="line"><a name="l00409"></a><span class="lineno">  409</span>&#160;                                          pn_ssl_hash_alg hash_alg);</div><div class="line"><a name="l00410"></a><span class="lineno">  410</span>&#160;</div><div class="line"><a name="l00423"></a><span class="lineno">  423</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span>* <a class="code" href="group__ssl.html#ga0c9e8827536b9929793045771d82bdf1">pn_ssl_get_remote_subject_subfield</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl0, pn_ssl_cert_subject_subfield field);</div><div class="line"><a name="l00424"></a><span class="lineno">  424</span>&#160;</div><div class="line"><a name="l00429"></a><span class="lineno">  429</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00430"></a><span c
 lass="lineno">  430</span>&#160;}</div><div class="line"><a name="l00431"></a><span class="lineno">  431</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00432"></a><span class="lineno">  432</span>&#160;</div><div class="line"><a name="l00433"></a><span class="lineno">  433</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* ssl.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
+<a href="ssl_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_SSL_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_SSL_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  Se
 e the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> 
 *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div c
 lass="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00027"></a><span class="lineno">   27</span
 >&#160;<span class="preprocessor">#include &lt;<a class="code" href="types_8h.html">proton/types.h</a>&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;</div><div class="line"><a name="l00080"></a><span class="lineno"><a class="line" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">   80</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__ssl.html#gaba83c3a1779
 c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a>;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno"><a class="line" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">   85</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">struct </span><a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> <a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a>;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00090"></a><span class="lineno"><a class="line" href="group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225">   90</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00091"></a><spa
 n class="lineno"><a class="line" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c">   91</a></span>&#160;  <a class="code" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c">PN_SSL_MODE_CLIENT</a> = 1, </div><div class="line"><a name="l00092"></a><span class="lineno"><a class="line" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078">   92</a></span>&#160;  <a class="code" href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078">PN_SSL_MODE_SERVER</a>      </div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;} <a class="code" href="group__ssl.html#ga0f1d40875c45b14a31a77f27430bc225">pn_ssl_mode_t</a>;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00098"></a><span class="lineno"><a class="line" href="group__ssl.html#gaf175c116d5
 2a91001f9a3559b580f56d">   98</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00099"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d">   99</a></span>&#160;  <a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d">PN_SSL_RESUME_UNKNOWN</a>,        </div><div class="line"><a name="l00100"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f">  100</a></span>&#160;  <a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f">PN_SSL_RESUME_NEW</a>,            </div><div class="line"><a name="l00101"></a><span class="lineno"><a class="line" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d">  101</a></span>&#160;  <
 a class="code" href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d">PN_SSL_RESUME_REUSED</a>          </div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;} <a class="code" href="group__ssl.html#gaf175c116d52a91001f9a3559b580f56d">pn_ssl_resume_status_t</a>;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb">pn_ssl_present</a>( <span class="keywordtype">void</span> );</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;PN_EXTERN <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *<a class="code" href="group__ssl.html#gaab5e86
 b7a4d22943eba82c6e94b82357">pn_ssl_domain</a>(pn_ssl_mode_t mode);</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d">pn_ssl_domain_free</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN <span class="keywordtype">int</span>  <a class="code" href="group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa">pn_ssl_domain_set_credentials</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;     
                                        <span class="keyword">const</span> <span class="keywordtype">char</span> *credential_1,</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;                                            <span class="keyword">const</span> <span class="keywordtype">char</span> *credential_2,</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;                                            <span class="keyword">const</span> <span class="keywordtype">char</span> *password);</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga6cdf12ad6ff3d50ac1d31db3cff11c2d">pn_ssl_domain_set_trusted_ca_db</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class=
 "line"><a name="l00177"></a><span class="lineno">  177</span>&#160;                                <span class="keyword">const</span> <span class="keywordtype">char</span> *certificate_db);</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;</div><div class="line"><a name="l00195"></a><span class="lineno"><a class="line" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">  195</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00196"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc">  196</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc">PN_SSL_VERIFY_NULL</a> = 0,   </div><div class="line"><a name="l00197"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95
 760c63d0b9685d4d44">  197</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44">PN_SSL_VERIFY_PEER</a>,       </div><div class="line"><a name="l00198"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5">  198</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5">PN_SSL_ANONYMOUS_PEER</a>,    </div><div class="line"><a name="l00199"></a><span class="lineno"><a class="line" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36">  199</a></span>&#160;  <a class="code" href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36">PN_SSL_VERIFY_PEER_NAME</a>   </div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;} <a class="code" href="group__ssl.html#gae5e33024ed6af3432
 d4c76d1484d7ecb">pn_ssl_verify_mode_t</a>;</div><div class="line"><a name="l00201"></a><span class="lineno">  201</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">pn_ssl_domain_set_peer_authentication</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;                                                    <span class="keyword">const</span> pn_ssl_verify_mode_t mode,</div><div class="line"><a name="l00227"></a><span class="lineno">  227</span>&#160;                                                    <span class="keyword">const</span> <span class="keywordtype">char</span> *trusted_CAs);</div><div class="line"><a name="l00228"></a><span class="lineno">  228</span>&#160;</div><div class="
 line"><a name="l00242"></a><span class="lineno">  242</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">pn_ssl_domain_set_protocols</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, <span class="keyword">const</span> <span class="keywordtype">char</span> *protocols);</div><div class="line"><a name="l00243"></a><span class="lineno">  243</span>&#160;</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">pn_ssl_domain_set_ciphers</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain, <span class="keyword">const</span> <span class="keywordtype">char</span> *ciphers);</div><div class="line"><a name="l00255"></a><span class="lineno">  255</span>&#160;<
 /div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">pn_ssl_domain_allow_unsecured_client</a>(<a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain);</div><div class="line"><a name="l00267"></a><span class="lineno">  267</span>&#160;</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;PN_EXTERN <a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *<a class="code" href="group__ssl.html#gaaeb5284b45f9e2146ff671b1ddc9420c">pn_ssl</a>(<a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport);</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;</div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;PN_EXTERN <span cla
 ss="keywordtype">int</span> <a class="code" href="group__ssl.html#ga45f319dd31ad456b8a85927888f94acf">pn_ssl_init</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl,</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;                          <a class="code" href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a> *domain,</div><div class="line"><a name="l00296"></a><span class="lineno">  296</span>&#160;                          <span class="keyword">const</span> <span class="keywordtype">char</span> *session_id);</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;</div><div class="line"><a name="l00311"></a><span class="lineno">  311</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52">pn_ssl_get_cipher_name</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605
 ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keywordtype">char</span> *buffer, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00312"></a><span class="lineno">  312</span>&#160;</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga7fa81d6e5f9b28f90558ab8dd3c4fb1d">pn_ssl_get_ssf</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00320"></a><span class="lineno">  320</span>&#160;</div><div class="line"><a name="l00333"></a><span class="lineno">  333</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__ssl.html#ga03e8070271747c3901d8d6e5710c0066">pn_ssl_get_protocol_name</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keywordtype">char</span> *buffer, <span class="
 keywordtype">size_t</span> size);</div><div class="line"><a name="l00334"></a><span class="lineno">  334</span>&#160;</div><div class="line"><a name="l00348"></a><span class="lineno">  348</span>&#160;PN_EXTERN pn_ssl_resume_status_t <a class="code" href="group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f">pn_ssl_resume_status</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00349"></a><span class="lineno">  349</span>&#160;</div><div class="line"><a name="l00372"></a><span class="lineno">  372</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a">pn_ssl_set_peer_hostname</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keyword">const</span> <span class="keywordtype">char</span> *hostname);</div><div class="line"><a name="l00373"></a><span class="lineno">  373</spa
 n>&#160;</div><div class="line"><a name="l00387"></a><span class="lineno">  387</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga76636a5ce4696284356321226ee0731c">pn_ssl_get_peer_hostname</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl, <span class="keywordtype">char</span> *hostname, <span class="keywordtype">size_t</span> *bufsize);</div><div class="line"><a name="l00388"></a><span class="lineno">  388</span>&#160;</div><div class="line"><a name="l00396"></a><span class="lineno">  396</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span>* <a class="code" href="group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3">pn_ssl_get_remote_subject</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl);</div><div class="line"><a name="l00397"></a><span class="lineno">  397</span>&#160;</div><div class="line"><a nam
 e="l00401"></a><span class="lineno"><a class="line" href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">  401</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00402"></a><span class="lineno">  402</span>&#160;  PN_SSL_CERT_SUBJECT_COUNTRY_NAME,</div><div class="line"><a name="l00403"></a><span class="lineno">  403</span>&#160;  PN_SSL_CERT_SUBJECT_STATE_OR_PROVINCE,</div><div class="line"><a name="l00404"></a><span class="lineno">  404</span>&#160;  PN_SSL_CERT_SUBJECT_CITY_OR_LOCALITY,</div><div class="line"><a name="l00405"></a><span class="lineno">  405</span>&#160;  PN_SSL_CERT_SUBJECT_ORGANIZATION_NAME,</div><div class="line"><a name="l00406"></a><span class="lineno">  406</span>&#160;  PN_SSL_CERT_SUBJECT_ORGANIZATION_UNIT,</div><div class="line"><a name="l00407"></a><span class="lineno">  407</span>&#160;  PN_SSL_CERT_SUBJECT_COMMON_NAME</div><div class="line"><a name="l00408"></a><span class="line
 no">  408</span>&#160;} <a class="code" href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">pn_ssl_cert_subject_subfield</a>;</div><div class="line"><a name="l00409"></a><span class="lineno">  409</span>&#160;</div><div class="line"><a name="l00413"></a><span class="lineno"><a class="line" href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">  413</a></span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00414"></a><span class="lineno">  414</span>&#160;  PN_SSL_SHA1,   <span class="comment">/* Produces hash that is 20 bytes long */</span></div><div class="line"><a name="l00415"></a><span class="lineno">  415</span>&#160;  PN_SSL_SHA256, <span class="comment">/* Produces hash that is 32 bytes long */</span></div><div class="line"><a name="l00416"></a><span class="lineno">  416</span>&#160;  PN_SSL_SHA512, <span class="comment">/* Produces hash that is 64 bytes long */</span></div><div class="line"><a name="l0
 0417"></a><span class="lineno">  417</span>&#160;  PN_SSL_MD5     <span class="comment">/* Produces hash that is 16 bytes long */</span></div><div class="line"><a name="l00418"></a><span class="lineno">  418</span>&#160;} <a class="code" href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">pn_ssl_hash_alg</a>;</div><div class="line"><a name="l00419"></a><span class="lineno">  419</span>&#160;</div><div class="line"><a name="l00433"></a><span class="lineno">  433</span>&#160;PN_EXTERN <span class="keywordtype">int</span> <a class="code" href="group__ssl.html#ga324db5da83b1abad2e948481d65119d4">pn_ssl_get_cert_fingerprint</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl0,</div><div class="line"><a name="l00434"></a><span class="lineno">  434</span>&#160;                                          <span class="keywordtype">char</span> *fingerprint,</div><div class="line"><a name="l00435"></a><span class="lineno">  435</span>&#160;      
                                     <span class="keywordtype">size_t</span> fingerprint_length,</div><div class="line"><a name="l00436"></a><span class="lineno">  436</span>&#160;                                          pn_ssl_hash_alg hash_alg);</div><div class="line"><a name="l00437"></a><span class="lineno">  437</span>&#160;</div><div class="line"><a name="l00450"></a><span class="lineno">  450</span>&#160;PN_EXTERN <span class="keyword">const</span> <span class="keywordtype">char</span>* <a class="code" href="group__ssl.html#ga0c9e8827536b9929793045771d82bdf1">pn_ssl_get_remote_subject_subfield</a>(<a class="code" href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a> *ssl0, pn_ssl_cert_subject_subfield field);</div><div class="line"><a name="l00451"></a><span class="lineno">  451</span>&#160;</div><div class="line"><a name="l00456"></a><span class="lineno">  456</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l0
 0457"></a><span class="lineno">  457</span>&#160;}</div><div class="line"><a name="l00458"></a><span class="lineno">  458</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00459"></a><span class="lineno">  459</span>&#160;</div><div class="line"><a name="l00460"></a><span class="lineno">  460</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* ssl.h */</span><span class="preprocessor"></span></div><div class="ttc" id="types_8h_html"><div class="ttname"><a href="types_8h.html">types.h</a></div><div class="ttdoc">AMQP and API data types. </div></div>
 <div class="ttc" id="group__ssl_html_ga7311e46bb756474513f3c331e0c1b0aa"><div class="ttname"><a href="group__ssl.html#ga7311e46bb756474513f3c331e0c1b0aa">pn_ssl_domain_set_credentials</a></div><div class="ttdeci">int pn_ssl_domain_set_credentials(pn_ssl_domain_t *domain, const char *credential_1, const char *credential_2, const char *password)</div><div class="ttdoc">Set the certificate that identifies the local node to the remote. </div></div>
 <div class="ttc" id="group__ssl_html_ga324db5da83b1abad2e948481d65119d4"><div class="ttname"><a href="group__ssl.html#ga324db5da83b1abad2e948481d65119d4">pn_ssl_get_cert_fingerprint</a></div><div class="ttdeci">int pn_ssl_get_cert_fingerprint(pn_ssl_t *ssl0, char *fingerprint, size_t fingerprint_length, pn_ssl_hash_alg hash_alg)</div><div class="ttdoc">Get the fingerprint of the certificate. </div></div>
 <div class="ttc" id="group__ssl_html_ga39b67bd22fb8f0a47bcdbdfd40f80b11"><div class="ttname"><a href="group__ssl.html#ga39b67bd22fb8f0a47bcdbdfd40f80b11">pn_ssl_domain_set_peer_authentication</a></div><div class="ttdeci">int pn_ssl_domain_set_peer_authentication(pn_ssl_domain_t *domain, const pn_ssl_verify_mode_t mode, const char *trusted_CAs)</div><div class="ttdoc">Configure the level of verification used on the peer certificate. </div></div>
 <div class="ttc" id="group__ssl_html_ga11c877302188bc852cfdc9efd6de58c3"><div class="ttname"><a href="group__ssl.html#ga11c877302188bc852cfdc9efd6de58c3">pn_ssl_get_remote_subject</a></div><div class="ttdeci">const char * pn_ssl_get_remote_subject(pn_ssl_t *ssl)</div><div class="ttdoc">Get the subject from the peers certificate. </div></div>
-<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:433</div></div>
+<div class="ttc" id="group__transport_html_gac26eda05f649bbf0399f3d8d78d12fa8"><div class="ttname"><a href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a></div><div class="ttdeci">struct pn_transport_t pn_transport_t</div><div class="ttdoc">A network channel supporting an AMQP connection. </div><div class="ttdef"><b>Definition:</b> types.h:431</div></div>
 <div class="ttc" id="group__ssl_html_ga2ac989a62dcd138be770fae0bbb85e74"><div class="ttname"><a href="group__ssl.html#ga2ac989a62dcd138be770fae0bbb85e74">pn_ssl_domain_allow_unsecured_client</a></div><div class="ttdeci">int pn_ssl_domain_allow_unsecured_client(pn_ssl_domain_t *domain)</div><div class="ttdoc">Permit a server to accept connection requests from non-SSL clients. </div></div>
 <div class="ttc" id="group__ssl_html_ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36"><div class="ttname"><a href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbaac956f0febf05ab579de839700895e36">PN_SSL_VERIFY_PEER_NAME</a></div><div class="ttdoc">require valid certificate and matching name </div><div class="ttdef"><b>Definition:</b> ssl.h:199</div></div>
 <div class="ttc" id="group__ssl_html_ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44"><div class="ttname"><a href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbad80276abde5d95760c63d0b9685d4d44">PN_SSL_VERIFY_PEER</a></div><div class="ttdoc">require peer to provide a valid identifying certificate </div><div class="ttdef"><b>Definition:</b> ssl.h:197</div></div>
-<div class="ttc" id="group__ssl_html_ga68d52866e8172acc7ecc7b4fe5b38a40"><div class="ttname"><a href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">pn_ssl_cert_subject_subfield</a></div><div class="ttdeci">pn_ssl_cert_subject_subfield</div><div class="ttdoc">Enumeration identifying the sub fields of the subject field in the ssl certificate. </div><div class="ttdef"><b>Definition:</b> ssl.h:374</div></div>
+<div class="ttc" id="group__ssl_html_ga68d52866e8172acc7ecc7b4fe5b38a40"><div class="ttname"><a href="group__ssl.html#ga68d52866e8172acc7ecc7b4fe5b38a40">pn_ssl_cert_subject_subfield</a></div><div class="ttdeci">pn_ssl_cert_subject_subfield</div><div class="ttdoc">Enumeration identifying the sub fields of the subject field in the ssl certificate. </div><div class="ttdef"><b>Definition:</b> ssl.h:401</div></div>
 <div class="ttc" id="group__ssl_html_gae5e33024ed6af3432d4c76d1484d7ecb"><div class="ttname"><a href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a></div><div class="ttdeci">pn_ssl_verify_mode_t</div><div class="ttdoc">Determines the level of peer validation. </div><div class="ttdef"><b>Definition:</b> ssl.h:195</div></div>
 <div class="ttc" id="group__ssl_html_ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d"><div class="ttname"><a href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dad1385651f6078177d6652c385453280d">PN_SSL_RESUME_UNKNOWN</a></div><div class="ttdoc">Session resume state unknown/not supported. </div><div class="ttdef"><b>Definition:</b> ssl.h:99</div></div>
 <div class="ttc" id="group__ssl_html_gaec849c8189c12da727e7be7ca757dbdb"><div class="ttname"><a href="group__ssl.html#gaec849c8189c12da727e7be7ca757dbdb">pn_ssl_present</a></div><div class="ttdeci">bool pn_ssl_present(void)</div><div class="ttdoc">Tests for SSL implementation present. </div></div>
@@ -115,17 +115,19 @@ $(document).ready(function(){initNavTree('ssl_8h_source.html','');});
 <div class="ttc" id="group__ssl_html_gaf175c116d52a91001f9a3559b580f56d"><div class="ttname"><a href="group__ssl.html#gaf175c116d52a91001f9a3559b580f56d">pn_ssl_resume_status_t</a></div><div class="ttdeci">pn_ssl_resume_status_t</div><div class="ttdoc">Indicates whether an SSL session has been resumed. </div><div class="ttdef"><b>Definition:</b> ssl.h:98</div></div>
 <div class="ttc" id="group__ssl_html_ga76636a5ce4696284356321226ee0731c"><div class="ttname"><a href="group__ssl.html#ga76636a5ce4696284356321226ee0731c">pn_ssl_get_peer_hostname</a></div><div class="ttdeci">int pn_ssl_get_peer_hostname(pn_ssl_t *ssl, char *hostname, size_t *bufsize)</div><div class="ttdoc">Access the configured peer identity. </div></div>
 <div class="ttc" id="group__ssl_html_gaba83c3a1779c8b35a479bf3a7bb5b175"><div class="ttname"><a href="group__ssl.html#gaba83c3a1779c8b35a479bf3a7bb5b175">pn_ssl_domain_t</a></div><div class="ttdeci">struct pn_ssl_domain_t pn_ssl_domain_t</div><div class="ttdoc">API for using SSL with the Transport Layer. </div><div class="ttdef"><b>Definition:</b> ssl.h:80</div></div>
+<div class="ttc" id="group__ssl_html_ga333fcb941ed20421373f37b23d84fc98"><div class="ttname"><a href="group__ssl.html#ga333fcb941ed20421373f37b23d84fc98">pn_ssl_domain_set_protocols</a></div><div class="ttdeci">int pn_ssl_domain_set_protocols(pn_ssl_domain_t *domain, const char *protocols)</div><div class="ttdoc">Configure the list of permitted TLS protocols. </div></div>
 <div class="ttc" id="group__ssl_html_ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d"><div class="ttname"><a href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dabb1b88b78dcb91ee80cd6f0eb5873d6d">PN_SSL_RESUME_REUSED</a></div><div class="ttdoc">Session resumed from previous session. </div><div class="ttdef"><b>Definition:</b> ssl.h:101</div></div>
 <div class="ttc" id="group__ssl_html_ga5f1a1d6697994bac00edc3df200a8f5f"><div class="ttname"><a href="group__ssl.html#ga5f1a1d6697994bac00edc3df200a8f5f">pn_ssl_resume_status</a></div><div class="ttdeci">pn_ssl_resume_status_t pn_ssl_resume_status(pn_ssl_t *ssl)</div><div class="ttdoc">Check whether the state has been resumed. </div></div>
 <div class="ttc" id="group__ssl_html_ga0c9e8827536b9929793045771d82bdf1"><div class="ttname"><a href="group__ssl.html#ga0c9e8827536b9929793045771d82bdf1">pn_ssl_get_remote_subject_subfield</a></div><div class="ttdeci">const char * pn_ssl_get_remote_subject_subfield(pn_ssl_t *ssl0, pn_ssl_cert_subject_subfield field)</div><div class="ttdoc">Returns a char pointer that contains the value of the sub field of the subject field in the ssl certi...</div></div>
 <div class="ttc" id="group__ssl_html_ga215da63662423b00d34605ba4f9761f5"><div class="ttname"><a href="group__ssl.html#ga215da63662423b00d34605ba4f9761f5">pn_ssl_t</a></div><div class="ttdeci">struct pn_ssl_t pn_ssl_t</div><div class="ttdef"><b>Definition:</b> ssl.h:85</div></div>
+<div class="ttc" id="group__ssl_html_gac3da0f48aeeb11d8149a559a2a064ddc"><div class="ttname"><a href="group__ssl.html#gac3da0f48aeeb11d8149a559a2a064ddc">pn_ssl_domain_set_ciphers</a></div><div class="ttdeci">int pn_ssl_domain_set_ciphers(pn_ssl_domain_t *domain, const char *ciphers)</div><div class="ttdoc">Configure the list of permitted ciphers. </div></div>
 <div class="ttc" id="group__ssl_html_ga5452ded9c36d78a17c6dea292a01c80d"><div class="ttname"><a href="group__ssl.html#ga5452ded9c36d78a17c6dea292a01c80d">pn_ssl_domain_free</a></div><div class="ttdeci">void pn_ssl_domain_free(pn_ssl_domain_t *domain)</div><div class="ttdoc">Release an SSL configuration domain. </div></div>
 <div class="ttc" id="group__ssl_html_ga47653f84f4b5e3bad46c08d4e82a2c52"><div class="ttname"><a href="group__ssl.html#ga47653f84f4b5e3bad46c08d4e82a2c52">pn_ssl_get_cipher_name</a></div><div class="ttdeci">bool pn_ssl_get_cipher_name(pn_ssl_t *ssl, char *buffer, size_t size)</div><div class="ttdoc">Get the name of the Cipher that is currently in use. </div></div>
 <div class="ttc" id="group__ssl_html_gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078"><div class="ttname"><a href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a0c4550c70a6bc74cb906a74c5f1e5078">PN_SSL_MODE_SERVER</a></div><div class="ttdoc">Local connection endpoint is an SSL server. </div><div class="ttdef"><b>Definition:</b> ssl.h:92</div></div>
 <div class="ttc" id="group__ssl_html_ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f"><div class="ttname"><a href="group__ssl.html#ggaf175c116d52a91001f9a3559b580f56dac8a5515a69c89007f681b3c555328e8f">PN_SSL_RESUME_NEW</a></div><div class="ttdoc">Session renegotiated - not resumed. </div><div class="ttdef"><b>Definition:</b> ssl.h:100</div></div>
 <div class="ttc" id="group__ssl_html_gaab5e86b7a4d22943eba82c6e94b82357"><div class="ttname"><a href="group__ssl.html#gaab5e86b7a4d22943eba82c6e94b82357">pn_ssl_domain</a></div><div class="ttdeci">pn_ssl_domain_t * pn_ssl_domain(pn_ssl_mode_t mode)</div><div class="ttdoc">Create an SSL configuration domain. </div></div>
 <div class="ttc" id="group__ssl_html_gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c"><div class="ttname"><a href="group__ssl.html#gga0f1d40875c45b14a31a77f27430bc225a4e2fe24fcd2692e4c20c27668091a49c">PN_SSL_MODE_CLIENT</a></div><div class="ttdoc">Local connection endpoint is an SSL client. </div><div class="ttdef"><b>Definition:</b> ssl.h:91</div></div>
-<div class="ttc" id="group__ssl_html_gaf0b0cd3271ad4a0e33e2a61a8cea7892"><div class="ttname"><a href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">pn_ssl_hash_alg</a></div><div class="ttdeci">pn_ssl_hash_alg</div><div class="ttdoc">Enumeration identifying hashing algorithm. </div><div class="ttdef"><b>Definition:</b> ssl.h:386</div></div>
+<div class="ttc" id="group__ssl_html_gaf0b0cd3271ad4a0e33e2a61a8cea7892"><div class="ttname"><a href="group__ssl.html#gaf0b0cd3271ad4a0e33e2a61a8cea7892">pn_ssl_hash_alg</a></div><div class="ttdeci">pn_ssl_hash_alg</div><div class="ttdoc">Enumeration identifying hashing algorithm. </div><div class="ttdef"><b>Definition:</b> ssl.h:413</div></div>
 <div class="ttc" id="group__ssl_html_ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc"><div class="ttname"><a href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbada1e3837cc900bd6419de72c25b253cc">PN_SSL_VERIFY_NULL</a></div><div class="ttdoc">internal use only </div><div class="ttdef"><b>Definition:</b> ssl.h:196</div></div>
 <div class="ttc" id="group__ssl_html_ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5"><div class="ttname"><a href="group__ssl.html#ggae5e33024ed6af3432d4c76d1484d7ecbafa6dbe705dd0366ff4799616f788a9f5">PN_SSL_ANONYMOUS_PEER</a></div><div class="ttdoc">do not require a certificate nor cipher authorization </div><div class="ttdef"><b>Definition:</b> ssl.h:198</div></div>
 <div class="ttc" id="group__ssl_html_ga15d46dcd823ebd42b9f7f63ed570080a"><div class="ttname"><a href="group__ssl.html#ga15d46dcd823ebd42b9f7f63ed570080a">pn_ssl_set_peer_hostname</a></div><div class="ttdeci">int pn_ssl_set_peer_hostname(pn_ssl_t *ssl, const char *hostname)</div><div class="ttdoc">Set the expected identity of the remote peer. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/terminus_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/terminus_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/terminus_8h_source.html
index b4d8462..277231f 100755
--- a/content/releases/qpid-proton-master/proton/c/api/terminus_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/terminus_8h_source.html
@@ -118,7 +118,7 @@ $(document).ready(function(){initNavTree('terminus_8h_source.html','');});
 <div class="ttc" id="group__terminus_html_gae9c9515f94353eb82cb421e46ce4bb24"><div class="ttname"><a href="group__terminus.html#gae9c9515f94353eb82cb421e46ce4bb24">pn_terminus_properties</a></div><div class="ttdeci">pn_data_t * pn_terminus_properties(pn_terminus_t *terminus)</div><div class="ttdoc">Access/modify the AMQP properties data for a terminus object. </div></div>
 <div class="ttc" id="group__data_html_ga5d6cf528776e8b6ad6d67caf095986bf"><div class="ttname"><a href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a></div><div class="ttdeci">struct pn_data_t pn_data_t</div><div class="ttdoc">An AMQP Data object. </div><div class="ttdef"><b>Definition:</b> codec.h:364</div></div>
 <div class="ttc" id="group__terminus_html_ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac"><div class="ttname"><a href="group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a74d3ae9ce3ad50e5c5cc71164a2a8aac">PN_DIST_MODE_UNSPECIFIED</a></div><div class="ttdoc">the behaviour is defined by the node </div><div class="ttdef"><b>Definition:</b> terminus.h:107</div></div>
-<div class="ttc" id="group__api__types_html_gafdede9be0526a8d0b9ab5d3149069af1"><div class="ttname"><a href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a></div><div class="ttdeci">uint32_t pn_seconds_t</div><div class="ttdoc">A span of time in seconds. </div><div class="ttdef"><b>Definition:</b> types.h:161</div></div>
+<div class="ttc" id="group__api__types_html_gafdede9be0526a8d0b9ab5d3149069af1"><div class="ttname"><a href="group__api__types.html#gafdede9be0526a8d0b9ab5d3149069af1">pn_seconds_t</a></div><div class="ttdeci">uint32_t pn_seconds_t</div><div class="ttdoc">A span of time in seconds. </div><div class="ttdef"><b>Definition:</b> types.h:159</div></div>
 <div class="ttc" id="group__terminus_html_ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92"><div class="ttname"><a href="group__terminus.html#ggac6fb89a5fa96476db51b60f10dc785d0a9e076691930f95f32c850ea01a808b92">PN_DIST_MODE_MOVE</a></div><div class="ttdoc">the receiver competes for messages </div><div class="ttdef"><b>Definition:</b> terminus.h:109</div></div>
 <div class="ttc" id="group__terminus_html_gab4089b27ee99a348deab776f3d4931f0"><div class="ttname"><a href="group__terminus.html#gab4089b27ee99a348deab776f3d4931f0">pn_expiry_policy_t</a></div><div class="ttdeci">pn_expiry_policy_t</div><div class="ttdoc">Expiry policy of an AMQP terminus. </div><div class="ttdef"><b>Definition:</b> terminus.h:92</div></div>
 <div class="ttc" id="group__terminus_html_ga0f9df2253065f81fd304f39a846e6468"><div class="ttname"><a href="group__terminus.html#ga0f9df2253065f81fd304f39a846e6468">pn_terminus_get_expiry_policy</a></div><div class="ttdeci">pn_expiry_policy_t pn_terminus_get_expiry_policy(pn_terminus_t *terminus)</div><div class="ttdoc">Get the expiry policy of a terminus object. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/transport_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/transport_8h.html b/content/releases/qpid-proton-master/proton/c/api/transport_8h.html
index 5c4c5eb..0ff87b4 100755
--- a/content/releases/qpid-proton-master/proton/c/api/transport_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/transport_8h.html
@@ -168,7 +168,9 @@ Functions</h2></td></tr>
 <tr class="memitem:gac458d9fdb684f9501e89b96fc51f5c34"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gac458d9fdb684f9501e89b96fc51f5c34"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get additional information about the condition of the transport.  <a href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">More...</a><br /></td></tr>
 <tr class="separator:gac458d9fdb684f9501e89b96fc51f5c34"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memitem:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memItemLeft" align="right" valign="top">
+<a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:gaede0bc2a0038ccdc7e1b193e322147fa"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga1a769e2e6c900c78c710407296cb4e13"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">pn_transport_bind</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, <a class="el" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection)</td></tr>
 <tr class="memdesc:ga1a769e2e6c900c78c710407296cb4e13"><td class="mdescLeft">&#160;</td><td class="mdescRight">Binds the transport to an AMQP connection.  <a href="group__transport.html#ga1a769e2e6c900c78c710407296cb4e13">More...</a><br /></td></tr>
@@ -186,8 +188,10 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga30d129d04a387ea34515c1641b83521b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the tracing function used by a transport.  <a href="group__transport.html#ga30d129d04a387ea34515c1641b83521b">More...</a><br /></td></tr>
 <tr class="separator:ga30d129d04a387ea34515c1641b83521b"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga000b2b9ab82139defb1a103f220ec58e"><td class="memItemLeft" align="right" valign="top">void *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
+<tr class="memdesc:ga000b2b9ab82139defb1a103f220ec58e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>.  <a href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">More...</a><br /></td></tr>
 <tr class="separator:ga000b2b9ab82139defb1a103f220ec58e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac22041ff85d1a1f5287ac2ba826edb74"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, void *context)</td></tr>
+<tr class="memdesc:gac22041ff85d1a1f5287ac2ba826edb74"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864" title="Get the attachments that are associated with a transport object. ">pn_transport_attachments()</a>.  <a href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">More...</a><br /></td></tr>
 <tr class="separator:gac22041ff85d1a1f5287ac2ba826edb74"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gabdd6d56837a028097b1676350d65a864"><td class="memItemLeft" align="right" valign="top">pn_record_t *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gabdd6d56837a028097b1676350d65a864">pn_transport_attachments</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gabdd6d56837a028097b1676350d65a864"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the attachments that are associated with a transport object.  <a href="group__transport.html#gabdd6d56837a028097b1676350d65a864">More...</a><br /></td></tr>
@@ -228,9 +232,13 @@ Functions</h2></td></tr>
 <tr class="memitem:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__api__types.html#ga9a701bc6dc9af9f42c3f4679172a723c">pn_millis_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5">pn_transport_get_remote_idle_timeout</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the idle timeout for a transport's remote peer.  <a href="group__transport.html#gabdcbd5d08c5b5cd3603dee74421985b5">More...</a><br /></td></tr>
 <tr class="separator:gabdcbd5d08c5b5cd3603dee74421985b5"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *bytes, size_t available)</td></tr>
+<tr class="memitem:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memItemLeft" align="right" valign="top">
+ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, const char *bytes, size_t available)</td></tr>
+<tr class="memdesc:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:ga93f5efd9d63ebd1b1498fdace388ec3d"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, char *bytes, size_t size)</td></tr>
+<tr class="memitem:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memItemLeft" align="right" valign="top">
+ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport, char *bytes, size_t size)</td></tr>
+<tr class="memdesc:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> <br /></td></tr>
 <tr class="separator:gae72fdee3b8aae3cb484b0ed98c2b802e"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaa079bb5f5b9ea10734c9d8af26fba333"><td class="memItemLeft" align="right" valign="top">ssize_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">pn_transport_capacity</a> (<a class="el" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *transport)</td></tr>
 <tr class="memdesc:gaa079bb5f5b9ea10734c9d8af26fba333"><td class="mdescLeft">&#160;</td><td class="mdescRight">Get the amount of free space for input following the transport's tail pointer.  <a href="group__transport.html#gaa079bb5f5b9ea10734c9d8af26fba333">More...</a><br /></td></tr>


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


[50/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/broker_8c-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/broker_8c-example.html b/content/releases/qpid-proton-master/proton/c/api/broker_8c-example.html
index 5880d4c..b40672a 100755
--- a/content/releases/qpid-proton-master/proton/c/api/broker_8c-example.html
+++ b/content/releases/qpid-proton-master/proton/c/api/broker_8c-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('broker_8c-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>A simple multithreaded broker that works with the <a class="el" href="send_8c-example.html">send.c</a> and <a class="el" href="receive_8c-example.html">receive.c</a> examples.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> *   http://www.apache.org/li
 censes/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;thread.h&quot;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;proton/engine.h
 &gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="listener_8h.html">proton/listener.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="proactor_8h.html">proton/proactor.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="sasl_8h.html">proton/sasl.h</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="transport_8h.html">proton/transport.h</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;stdio.h&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;stdlib.h&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;string.h&gt;</span></div><div class="line"></div><div class="line"><span class="comment">/* Simple re-sizable vector that acts as a queue */</span></div><div class="line"><span class="preprocesso
 r">#define VEC(T) struct { T* data; size_t len, cap; }</span></div><div class="line"></div><div class="line"><span class="preprocessor">#define VEC_INIT(V)                             \</span></div><div class="line"><span class="preprocessor">  do {                                          \</span></div><div class="line"><span class="preprocessor">    V.len = 0;                                  \</span></div><div class="line"><span class="preprocessor">    V.cap = 16;                                 \</span></div><div class="line"><span class="preprocessor">    void **vp = (void**)&amp;V.data;                \</span></div><div class="line"><span class="preprocessor">    *vp = malloc(V.cap * sizeof(*V.data));      \</span></div><div class="line"><span class="preprocessor">  } while(0)</span></div><div class="line"></div><div class="line"><span class="preprocessor">#define VEC_FINAL(V) free(V.data)</span></div><div class="line"></div><div class="line"><span class="preprocessor">#defin
 e VEC_PUSH(V, X)                                  \</span></div><div class="line"><span class="preprocessor">  do {                                                  \</span></div><div class="line"><span class="preprocessor">    if (V.len == V.cap) {                               \</span></div><div class="line"><span class="preprocessor">      V.cap *= 2;                                       \</span></div><div class="line"><span class="preprocessor">      void **vp = (void**)&amp;V.data;                      \</span></div><div class="line"><span class="preprocessor">      *vp = realloc(V.data, V.cap * sizeof(*V.data));   \</span></div><div class="line"><span class="preprocessor">    }                                                   \</span></div><div class="line"><span class="preprocessor">    V.data[V.len++] = X;                                \</span></div><div class="line"><span class="preprocessor">  } while(0)                                            \</span></div><div clas
 s="line"><span class="preprocessor"></span></div><div class="line"><span class="preprocessor">#define VEC_POP(V)                                              \</span></div><div class="line"><span class="preprocessor">  do {                                                          \</span></div><div class="line"><span class="preprocessor">    if (V.len &gt; 0)                                              \</span></div><div class="line"><span class="preprocessor">      memmove(V.data, V.data+1, (--V.len)*sizeof(*V.data));     \</span></div><div class="line"><span class="preprocessor">  } while(0)</span></div><div class="line"></div><div class="line"><span class="comment">/* Simple thread-safe queue implementation */</span></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>queue_t {</div><div class="line">  pthread_mutex_t lock;</div><div class="line">  <span class="keywordtype">char</span> name[256];</div><div class="line">  VEC(<a name="_
 a0"></a><a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a>) messages;   <span class="comment">/* Messages on the queue_t */</span></div><div class="line">  VEC(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a>*) waiting; <span class="comment">/* Connections waiting to send messages from this queue */</span></div><div class="line">  <span class="keyword">struct </span>queue_t *next;            <span class="comment">/* Next queue in chain */</span></div><div class="line">  <span class="keywordtype">size_t</span> sent;                     <span class="comment">/* Count of messages sent, used as delivery tag */</span></div><div class="line">} queue_t;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> queue_init(queue_t *q, <span class="keyword">const</span> <span class="keywordtype">char</span>* name, queue_t *next) {</div><div class=
 "line">  pthread_mutex_init(&amp;q-&gt;lock, NULL);</div><div class="line">  strncpy(q-&gt;name, name, <span class="keyword">sizeof</span>(q-&gt;name));</div><div class="line">  VEC_INIT(q-&gt;messages);</div><div class="line">  VEC_INIT(q-&gt;waiting);</div><div class="line">  q-&gt;next = next;</div><div class="line">  q-&gt;sent = 0;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> queue_destroy(queue_t *q) {</div><div class="line">  pthread_mutex_destroy(&amp;q-&gt;lock);</div><div class="line">  free(q-&gt;name);</div><div class="line">  <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; q-&gt;messages.len; ++i)</div><div class="line">    free(q-&gt;messages.data[i].start);</div><div class="line">  VEC_FINAL(q-&gt;messages);</div><div class="line">  <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; q-
 &gt;waiting.len; ++i)</div><div class="line">    pn_decref(q-&gt;waiting.data[i]);</div><div class="line">  VEC_FINAL(q-&gt;waiting);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Send a message on s, or record s as eating if no messages.</span></div><div class="line"><span class="comment">   Called in s dispatch loop, assumes s has credit.</span></div><div class="line"><span class="comment">*/</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> queue_send(queue_t *q, <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *s) {</div><div class="line">  <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> m = { 0 };</div><div class="line">  <span class="keywordtype">size_t</span> tag = 0;</div><div class="line">  pthread_mutex_lock(&amp;q-&gt;lock);</div><div class="line">  <span class="keywordflow">if</span> (q-&gt;me
 ssages.len == 0) { <span class="comment">/* Empty, record connection as waiting */</span></div><div class="line">    <span class="comment">/* Record connection for wake-up if not already on the list. */</span></div><div class="line">    <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c = <a name="a1"></a><a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(<a name="a2"></a><a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(s));</div><div class="line">    <span class="keywordtype">size_t</span> i = 0;</div><div class="line">    <span class="keywordflow">for</span> (; i &lt; q-&gt;waiting.len &amp;&amp; q-&gt;waiting.data[i] != c; ++i)</div><div class="line">      ;</div><div class="line">    <span class="keywordflow">if</span> (i == q-&gt;waiting.len) {</div><div class="line">      VEC_PUSH(q-&gt;waiting, c);</div><div class="line">    }
 </div><div class="line">  } <span class="keywordflow">else</span> {</div><div class="line">    m = q-&gt;messages.data[0];</div><div class="line">    VEC_POP(q-&gt;messages);</div><div class="line">    tag = ++q-&gt;sent;</div><div class="line">  }</div><div class="line">  pthread_mutex_unlock(&amp;q-&gt;lock);</div><div class="line">  <span class="keywordflow">if</span> (m.<a name="a3"></a>start) {</div><div class="line">    <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *d = <a name="a4"></a><a class="code" href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a>(s, <a name="a5"></a><a class="code" href="group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a>((<span class="keywordtype">char</span>*)&amp;tag, <span class="keyword">sizeof</span>(tag)));</div><div class="line">    <a name="a6"></a><a class="code" href="group__link.html#gaa825fac21730f3f9fff37d156e5f88e9">pn_link_send</a>(s, m.start, 
 m.<a name="a7"></a>size);</div><div class="line">    <a name="a8"></a><a class="code" href="group__link.html#ga93824a3859c37463e44458cd2f63d31f">pn_link_advance</a>(s);</div><div class="line">    <a name="a9"></a><a class="code" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(d);  <span class="comment">/* Pre-settled: unreliable, there will bea no ack/ */</span></div><div class="line">    free(m.start);</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Data associated with each broker connection */</span></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>broker_data_t {</div><div class="line">  <span class="keywordtype">bool</span> check_queues;          <span class="comment">/* Check senders on the connection for available data in queues. */</span></div><div class="line">} broker_data_t;</div><div class="line"></div><div class
 ="line"><span class="comment">/* Use the context pointer as a boolean flag to indicate we need to check queues */</span></div><div class="line"><span class="keywordtype">void</span> pn_connection_set_check_queues(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c, <span class="keywordtype">bool</span> check) {</div><div class="line">  <a name="a10"></a><a class="code" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a>(c, (<span class="keywordtype">void</span>*)check);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">bool</span> pn_connection_get_check_queues(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c) {</div><div class="line">  <span class="keywordflow">return</span> (<span class="keywordtype">bool</span>)<a name="a11"></a><a class="code" href="group__connection.html#ga50613e6c09
 186dc3f1a2f36238c61f07">pn_connection_get_context</a>(c);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Put a message on the queue, called in receiver dispatch loop.</span></div><div class="line"><span class="comment">   If the queue was previously empty, notify waiting senders.</span></div><div class="line"><span class="comment">*/</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> queue_receive(<a class="code" href="types_8h.html#abba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *d, queue_t *q, <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> m) {</div><div class="line">  pthread_mutex_lock(&amp;q-&gt;lock);</div><div class="line">  VEC_PUSH(q-&gt;messages, m);</div><div class="line">  <span class="keywordflow">if</span> (q-&gt;messages.len == 1) { <span class="comment">/* Was empty, notify waiting connections */</span></div><div class="line
 ">    <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; q-&gt;waiting.len; ++i) {</div><div class="line">      <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c = q-&gt;waiting.data[i];</div><div class="line">      pn_connection_set_check_queues(c, <span class="keyword">true</span>);</div><div class="line">      <a name="a12"></a><a class="code" href="group__proactor.html#ga0f49c771fe3bff54f58c9d583ca30560">pn_connection_wake</a>(c); <span class="comment">/* Wake the connection */</span></div><div class="line">    }</div><div class="line">    q-&gt;waiting.len = 0;</div><div class="line">  }</div><div class="line">  pthread_mutex_unlock(&amp;q-&gt;lock);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Thread safe set of queues */</span></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>queues_t 
 {</div><div class="line">  pthread_mutex_t lock;</div><div class="line">  queue_t *queues;</div><div class="line">  <span class="keywordtype">size_t</span> sent;</div><div class="line">} queues_t;</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> queues_init(queues_t *qs) {</div><div class="line">  pthread_mutex_init(&amp;qs-&gt;lock, NULL);</div><div class="line">  qs-&gt;queues = NULL;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> queues_destroy(queues_t *qs) {</div><div class="line">  <span class="keywordflow">for</span> (queue_t *q = qs-&gt;queues; q; q = q-&gt;next) {</div><div class="line">    queue_destroy(q);</div><div class="line">    free(q);</div><div class="line">  }</div><div class="line">  pthread_mutex_destroy(&amp;qs-&gt;lock);</div><div class="line">}</div><div class="line"></div><div class="line">queue_t* queues_get(queues_t *qs, <span class="keyword">const</span> <sp
 an class="keywordtype">char</span>* name) {</div><div class="line">  pthread_mutex_lock(&amp;qs-&gt;lock);</div><div class="line">  queue_t *q;</div><div class="line">  <span class="keywordflow">for</span> (q = qs-&gt;queues; q &amp;&amp; strcmp(q-&gt;name, name) != 0; q = q-&gt;next)</div><div class="line">    ;</div><div class="line">  <span class="keywordflow">if</span> (!q) {</div><div class="line">    q = (queue_t*)malloc(<span class="keyword">sizeof</span>(queue_t));</div><div class="line">    queue_init(q, name, qs-&gt;queues);</div><div class="line">    qs-&gt;queues = q;</div><div class="line">  }</div><div class="line">  pthread_mutex_unlock(&amp;qs-&gt;lock);</div><div class="line">  <span class="keywordflow">return</span> q;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* The broker implementation */</span></div><div class="line"><span class="keyword">typedef</span> <span class="keyword">struct </span>broker_t {</div><div 
 class="line">  <a class="code" href="types_8h.html#abba42c7929dfceb9d296535bad0c93dc">pn_proactor_t</a> *proactor;</div><div class="line">  <span class="keywordtype">size_t</span> threads;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *container_id;     <span class="comment">/* AMQP container-id */</span></div><div class="line">  queues_t queues;</div><div class="line">  <span class="keywordtype">bool</span> finished;</div><div class="line">} broker_t;</div><div class="line"></div><div class="line"><span class="keywordtype">void</span> broker_stop(broker_t *b) {</div><div class="line">  <span class="comment">/* Interrupt the proactor to stop the working threads. */</span></div><div class="line">  <a name="a13"></a><a class="code" href="group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711">pn_proactor_interrupt</a>(b-&gt;proactor);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Tr
 y to send if link is sender and has credit */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> link_send(broker_t *b, <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *s) {</div><div class="line">  <span class="keywordflow">if</span> (<a name="a14"></a><a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(s) &amp;&amp; <a name="a15"></a><a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(s) &gt; 0) {</div><div class="line">    <span class="keyword">const</span> <span class="keywordtype">char</span> *qname = <a name="a16"></a><a class="code" href="group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a">pn_terminus_get_address</a>(<a name="a17"></a><a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(s));</div><div class="line">    queue_t *q = queues_get(&amp;b-&gt;
 queues, qname);</div><div class="line">    queue_send(q, s);</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> queue_unsub(queue_t *q, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c) {</div><div class="line">  pthread_mutex_lock(&amp;q-&gt;lock);</div><div class="line">  <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; q-&gt;waiting.len; ++i) {</div><div class="line">    <span class="keywordflow">if</span> (q-&gt;waiting.data[i] == c){</div><div class="line">      q-&gt;waiting.data[i] = q-&gt;waiting.data[0]; <span class="comment">/* save old [0] */</span></div><div class="line">      VEC_POP(q-&gt;waiting);</div><div class="line">      <span class="keywordflow">break</span>;</div><div class="line">    }</div><div class="line">  }</div><div class="line">  pthread
 _mutex_unlock(&amp;q-&gt;lock);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Unsubscribe from the queue of interest to this link. */</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> link_unsub(broker_t *b, <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *s) {</div><div class="line">  <span class="keywordflow">if</span> (<a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(s)) {</div><div class="line">    <span class="keyword">const</span> <span class="keywordtype">char</span> *qname = <a class="code" href="group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a">pn_terminus_get_address</a>(<a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(s));</div><div class="line">    <span class="keywordflow">if</span> (qname) {</div><div class="line">      queue_t
  *q = queues_get(&amp;b-&gt;queues, qname);</div><div class="line">      queue_unsub(q, <a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(<a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(s)));</div><div class="line">    }</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="comment">/* Called in connection&#39;s event loop when a connection is woken for messages.*/</span></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> connection_unsub(broker_t *b, <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c) {</div><div class="line">  <span class="keywordflow">for</span> (<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a name="a18"></a><a class="code" href="group__link.html#ga7c9434c40eb65
 3f007ff5721e2ebf73e">pn_link_head</a>(c, 0); l != NULL; l = <a name="a19"></a><a class="code" href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a>(l, 0))</div><div class="line">    link_unsub(b, l);</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> session_unsub(broker_t *b, <a class="code" href="group__session.html#ga38ccb93b8f5c2892adafce5d5f0fbcd9">pn_session_t</a> *ssn) {</div><div class="line">  <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c = <a class="code" href="group__session.html#gaa45a8aa758334528a86cb7914ebe8545">pn_session_connection</a>(ssn);</div><div class="line">  <span class="keywordflow">for</span> (<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a class="code" href="group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e">pn_link_head</a>(c, 0); l 
 != NULL; l = <a class="code" href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a>(l, 0)) {</div><div class="line">    <span class="keywordflow">if</span> (<a class="code" href="group__link.html#gac63e43305fb1a5e3b14399a9ddc8f24d">pn_link_session</a>(l) == ssn)</div><div class="line">      link_unsub(b, l);</div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">int</span> exit_code = 0;</div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> check_condition(<a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e, <a class="code" href="group__condition.html#ga11eb7db7d2c205169fe3d47c996a95a5">pn_condition_t</a> *cond) {</div><div class="line">  <span class="keywordflow">if</span> (<a name="a20"></a><a class="code" href="group__condition.html#ga112611a7a4087
 e050c476a430db2cfb9">pn_condition_is_set</a>(cond)) {</div><div class="line">    fprintf(stderr, <span class="stringliteral">&quot;%s: %s: %s\n&quot;</span>, <a name="a21"></a><a class="code" href="group__event.html#ga3a85c046c11ce692c23b9566b022d54b">pn_event_type_name</a>(<a name="a22"></a><a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(e)),</div><div class="line">            <a name="a23"></a><a class="code" href="group__condition.html#ga05b0d374d90f11d9ebbf818662569689">pn_condition_get_name</a>(cond), <a name="a24"></a><a class="code" href="group__condition.html#gaabebb65bfcf47b6f7d83ab6fb0153bb8">pn_condition_get_description</a>(cond));</div><div class="line">    exit_code = 1;              <span class="comment">/* Remeber there was an unexpected error */</span></div><div class="line">  }</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keyword">const</span> <span class="keywordtype">int</span> W
 INDOW=10;            <span class="comment">/* Incoming credit window */</span></div><div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span> handle(broker_t* b, <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a>* e) {</div><div class="line">  <a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *c = <a name="a25"></a><a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e);</div><div class="line"></div><div class="line">  <span class="keywordflow">switch</span> (<a class="code" href="group__event.html#gacaea54ca51885933b4987c131a3d1b0d">pn_event_type</a>(e)) {</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a26"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa6e25f00110ab278fd8b34fee00bd5fd7">PN_LISTENER_OPEN</a>:
 </div><div class="line">    printf(<span class="stringliteral">&quot;listening\n&quot;</span>);</div><div class="line">    fflush(stdout);</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a27"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa0602b15957883e7d00ccdff4abca992c">PN_LISTENER_ACCEPT</a>:</div><div class="line">    <a name="a28"></a><a class="code" href="group__listener.html#gaaee3c3f3822484bc2e370406abf5b736">pn_listener_accept</a>(<a name="a29"></a><a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(e), <a name="a30"></a><a class="code" href="group__connection.html#gaa9e59c468ec0568b1528f5f83c4b301d">pn_connection</a>());</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a na
 me="a31"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa182e571a0310028514bce66a41063a6e">PN_CONNECTION_INIT</a>:</div><div class="line">     <a name="a32"></a><a class="code" href="group__connection.html#gac4a34e0b1fc5665b26ae47a80a422a1a">pn_connection_set_container</a>(c, b-&gt;container_id);</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a33"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf61aa79ca82b3a8f5017dc735843fae5">PN_CONNECTION_BOUND</a>: {</div><div class="line">     <span class="comment">/* Turn off security */</span></div><div class="line">     <a class="code" href="group__transport.html#gac26eda05f649bbf0399f3d8d78d12fa8">pn_transport_t</a> *t = <a name="a34"></a><a class="code" href="group__connection.html#gad8bd46661ca997b9b2c2c38cb6983c59">pn_connection_transport</a>(c);</div><div cl
 ass="line">     <a name="a35"></a><a class="code" href="group__transport.html#ga285b4cced59c665ae178adf26128d3fc">pn_transport_require_auth</a>(t, <span class="keyword">false</span>);</div><div class="line">     <a name="a36"></a><a class="code" href="group__sasl.html#ga73299a6a22e141e7911a739590032625">pn_sasl_allowed_mechs</a>(<a name="a37"></a><a class="code" href="group__sasl.html#ga7968e80e2fe9360fc14cf865dd1ac21c">pn_sasl</a>(t), <span class="stringliteral">&quot;ANONYMOUS&quot;</span>);</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a38"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad48bce685db553740fa71cc36473b5cc">PN_CONNECTION_REMOTE_OPEN</a>: {</div><div class="line">     <a name="a39"></a><a class="code" href="group__connection.html#ga4c0a2d40bb95202477ccc5aaa7456670">pn_connection_open</a>(<a class="code" href="group
 __event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e)); <span class="comment">/* Complete the open */</span></div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a40"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa28a2bfee806bbc1fe31499c8eec39db0">PN_CONNECTION_WAKE</a>: {</div><div class="line">     <span class="keywordflow">if</span> (pn_connection_get_check_queues(c)) {</div><div class="line">       pn_connection_set_check_queues(c, <span class="keyword">false</span>);</div><div class="line">       <span class="keywordtype">int</span> flags = <a name="a41"></a><a class="code" href="group__connection.html#ga0c3bf54f0991944a2f6eea36b561fa2b">PN_LOCAL_ACTIVE</a>&amp;<a name="a42"></a><a class="code" href="group__connection.html#gad96220f2886c21a4f2eebc9487f53a87">PN_REMOTE_ACTIVE</a>;</div><div class="line">       
 <span class="keywordflow">for</span> (<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a class="code" href="group__link.html#ga7c9434c40eb653f007ff5721e2ebf73e">pn_link_head</a>(c, flags); l != NULL; l = <a class="code" href="group__link.html#ga9b2a9cfa00dfdae4e01bf75483433925">pn_link_next</a>(l, flags))</div><div class="line">         link_send(b, l);</div><div class="line">     }</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a43"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaf67df046bea45df34aea863d9541e806">PN_SESSION_REMOTE_OPEN</a>: {</div><div class="line">     <a name="a44"></a><a class="code" href="group__session.html#ga2b345eada2c15249caaefaa894d1aae3">pn_session_open</a>(<a name="a45"></a><a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_
 session</a>(e));</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a46"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa45edb44a6cc7908b5032944e08925307">PN_LINK_REMOTE_OPEN</a>: {</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *l = <a name="a47"></a><a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e);</div><div class="line">     <span class="keywordflow">if</span> (<a class="code" href="group__link.html#ga7c48ef214568267839aea04ed337926b">pn_link_is_sender</a>(l)) {</div><div class="line">       <span class="keyword">const</span> <span class="keywordtype">char</span> *source = <a class="code" href="group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a">pn_terminus_get_address</a>(<a name="a48"></a><a class="code" href=
 "group__link.html#gadf6b8ff6223465f21a481e9287f60671">pn_link_remote_source</a>(l));</div><div class="line">       <a name="a49"></a><a class="code" href="group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1">pn_terminus_set_address</a>(<a class="code" href="group__link.html#ga2c8985a9d44a813ab1739a91ae3708a3">pn_link_source</a>(l), source);</div><div class="line">     } <span class="keywordflow">else</span> {</div><div class="line">       <span class="keyword">const</span> <span class="keywordtype">char</span>* target = <a class="code" href="group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a">pn_terminus_get_address</a>(<a name="a50"></a><a class="code" href="group__link.html#gabf61668a66ae189dbb4820da6ee30d90">pn_link_remote_target</a>(l));</div><div class="line">       <a class="code" href="group__terminus.html#ga0603db45f03fcef0ef18f4f89ebf3de1">pn_terminus_set_address</a>(<a name="a51"></a><a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_lin
 k_target</a>(l), target);</div><div class="line">       <a name="a52"></a><a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(l, WINDOW);</div><div class="line">     }</div><div class="line">     <a name="a53"></a><a class="code" href="group__link.html#gaabaca3f5d03970a122240eebc588add6">pn_link_open</a>(l);</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a54"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa4eaecc54c07cdc9b0df7b1d536a7dc3f">PN_LINK_FLOW</a>: {</div><div class="line">     link_send(b, <a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e));</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="line">   <span class="keywordflow">case</span> <a name="a55"></a><a class="code" href=
 "group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa70bbfc163d85732b5652dc70fb3330fe">PN_DELIVERY</a>: {</div><div class="line">     <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *d = <a name="a56"></a><a class="code" href="group__event.html#ga10fa6f53bdabe0851ebb2d8a0bf6a52c">pn_event_delivery</a>(e);</div><div class="line">     <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *r = <a name="a57"></a><a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(d);</div><div class="line">     <span class="keywordflow">if</span> (<a name="a58"></a><a class="code" href="group__link.html#gae7045dd02f2c9450ff8737e005628d81">pn_link_is_receiver</a>(r) &amp;&amp;</div><div class="line">         <a name="a59"></a><a class="code" href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a>(d) &amp;&amp; !<a name="a60"></a><a class="co
 de" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a>(d))</div><div class="line">     {</div><div class="line">       <span class="keywordtype">size_t</span> size = <a name="a61"></a><a class="code" href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a>(d);</div><div class="line">       <span class="comment">/* The broker does not decode the message, just forwards it. */</span></div><div class="line">       <a class="code" href="group__api__types.html#structpn__rwbytes__t">pn_rwbytes_t</a> m = { size, (<span class="keywordtype">char</span>*)malloc(size) };</div><div class="line">       <a name="a62"></a><a class="code" href="group__link.html#ga06c97ce7396973dca0d311567f25f95a">pn_link_recv</a>(r, m.start, m.size);</div><div class="line">       <span class="keyword">const</span> <span class="keywordtype">char</span> *qname = <a class="code" href="group__terminus.html#ga3507b6cfe260a2bfaae9321235db7c9a">pn_terminus_g
 et_address</a>(<a class="code" href="group__link.html#ga997c85388b9fb30151ea3b40b946e958">pn_link_target</a>(r));</div><div class="line">       queue_receive(b-&gt;proactor, queues_get(&amp;b-&gt;queues, qname), m);</div><div class="line">       <a name="a63"></a><a class="code" href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a>(d, <a name="a64"></a><a class="code" href="group__delivery.html#gac64952b813a707586c6b3898e09552e4">PN_ACCEPTED</a>);</div><div class="line">       <a class="code" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(d);</div><div class="line">       <a class="code" href="group__link.html#gafec44cf1c79ec03f3ac009e1879e71a9">pn_link_flow</a>(r, WINDOW - <a class="code" href="group__link.html#ga55428637f3b8c446efd5fea3f26c932d">pn_link_credit</a>(r));</div><div class="line">     }</div><div class="line">     <span class="keywordflow">break</span>;</div><div class="line">   }</div><div class="l
 ine"></div><div class="line">   <span class="keywordflow">case</span> <a name="a65"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1ca722ce3c0b2c13a33636cded8430ba">PN_TRANSPORT_CLOSED</a>:</div><div class="line">    check_condition(e, <a name="a66"></a><a class="code" href="group__transport.html#gac458d9fdb684f9501e89b96fc51f5c34">pn_transport_condition</a>(<a name="a67"></a><a class="code" href="group__event.html#ga14525ae84870388141898bbf57f2b151">pn_event_transport</a>(e)));</div><div class="line">    connection_unsub(b, <a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a68"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa1252529cf9f03d214c9b4fea5cf11b2f">PN_CONNECTION_REMOTE_CLOSE</a>:</div><div cla
 ss="line">    check_condition(e, <a name="a69"></a><a class="code" href="group__connection.html#ga72a362389b99d8e891bf2e4fb4290754">pn_connection_remote_condition</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e)));</div><div class="line">    <a name="a70"></a><a class="code" href="group__connection.html#gac25afdf810ad188b2cb3bf31a7482ca0">pn_connection_close</a>(<a class="code" href="group__event.html#ga4f2c6a0fdf86a43e7e9874fcd2ccaf52">pn_event_connection</a>(e));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a71"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa3410075b825c59b8f4efdcddf5a5b135">PN_SESSION_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(e, <a name="a72"></a><a class="code" href="group__session.html#gae21b3fda1567bad1f8a8fe162ffaeece">pn_session_remo
 te_condition</a>(<a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(e)));</div><div class="line">    session_unsub(b, <a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(e));</div><div class="line">    <a name="a73"></a><a class="code" href="group__session.html#ga12e5c4e71b0df4087d16ccc8b63b42b5">pn_session_close</a>(<a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(e));</div><div class="line">    <a name="a74"></a><a class="code" href="group__session.html#ga0f95b5177494a68991d75444c2f6f812">pn_session_free</a>(<a class="code" href="group__event.html#gaf4af0bfbe0e0a8e432f0e803df14ecb5">pn_event_session</a>(e));</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a75"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b998
 42103cdaa1153f0108be071c31210dd1cd3e40a1f">PN_LINK_REMOTE_CLOSE</a>:</div><div class="line">    check_condition(e, <a name="a76"></a><a class="code" href="group__link.html#ga97dc5133125c9b7e4afbb1b76e6efe7b">pn_link_remote_condition</a>(<a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e)));</div><div class="line">    link_unsub(b, <a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e));</div><div class="line">    <a name="a77"></a><a class="code" href="group__link.html#ga4851693eb6a16fd9ab61e2df6f00770d">pn_link_close</a>(<a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e));</div><div class="line">    <a name="a78"></a><a class="code" href="group__link.html#gadd3b8899fe023d3506fb88d228d6b1b7">pn_link_free</a>(<a class="code" href="group__event.html#ga75f230ef55f03a1f943df79279f8d111">pn_event_link</a>(e));</div><div class="line">    <span class="keyword
 flow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a79"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaad5920df168cd28daaf253cad789d8aca">PN_LISTENER_CLOSE</a>:</div><div class="line">    check_condition(e, <a name="a80"></a><a class="code" href="group__listener.html#gaa49d0d11a9f46a75fbbbebf6def2d4b2">pn_listener_condition</a>(<a class="code" href="group__listener.html#ga6214da9323c8e6fcec8badc57a82e9df">pn_event_listener</a>(e)));</div><div class="line">    broker_stop(b);</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line"> <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a81"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaa894e93f167ef39e28a07c9cdf6b1181b">PN_PROACTOR_INACTIVE</a>:   <span class="comment
 ">/* listener and all connections closed */</span></div><div class="line">    broker_stop(b);</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">case</span> <a name="a82"></a><a class="code" href="group__event.html#gga4876e2eed24a4d4e4c52b99842103cdaaee05826a80e94b5b86c4544e4715f499">PN_PROACTOR_INTERRUPT</a>:</div><div class="line">    b-&gt;finished = <span class="keyword">true</span>;</div><div class="line">    <a class="code" href="group__proactor.html#gaa5255cd1bcb5d7f5639b53dc30712711">pn_proactor_interrupt</a>(b-&gt;proactor); <span class="comment">/* Pass along the interrupt to the other threads */</span></div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line"></div><div class="line">   <span class="keywordflow">default</span>:</div><div class="line">    <span class="keywordflow">break</span>;</div><div class="line">  }</div><div class="line">}</div><
 div class="line"></div><div class="line"><span class="keyword">static</span> <span class="keywordtype">void</span>* broker_thread(<span class="keywordtype">void</span> *void_broker) {</div><div class="line">  broker_t *b = (broker_t*)void_broker;</div><div class="line">  <span class="keywordflow">do</span> {</div><div class="line">    <a class="code" href="group__event.html#ga6bc581dfeaa8e8d46d07d37229d565c9">pn_event_batch_t</a> *events = <a name="a83"></a><a class="code" href="group__proactor.html#ga2b66a46f3e557010ec61bd105326753d">pn_proactor_wait</a>(b-&gt;proactor);</div><div class="line">    <a class="code" href="group__event.html#ga87f3028b4888632bbd56fb71ac737ae8">pn_event_t</a> *e;</div><div class="line">    <span class="keywordflow">while</span> ((e = <a name="a84"></a><a class="code" href="group__event.html#gac3fbf151357d3101ac294cb675348c76">pn_event_batch_next</a>(events))) {</div><div class="line">      handle(b, e);</div><div class="line">    }</div><div class="line"
 >    <a name="a85"></a><a class="code" href="group__proactor.html#gade60ff2292b74841766f953b906285c0">pn_proactor_done</a>(b-&gt;proactor, events);</div><div class="line">  } <span class="keywordflow">while</span>(!b-&gt;finished);</div><div class="line">  <span class="keywordflow">return</span> NULL;</div><div class="line">}</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">  broker_t b = {0};</div><div class="line">  b.proactor = <a name="a86"></a><a class="code" href="group__proactor.html#gac2a925b3de00efd8cd40fa9920169554">pn_proactor</a>();</div><div class="line">  queues_init(&amp;b.queues);</div><div class="line">  b.container_id = argv[0];</div><div class="line">  b.threads = 4;</div><div class="line">  <span class="keywordtype">int</span> i = 1;</div><div class="line">  <span class="keyword">const</span> <span class="keywor
 dtype">char</span> *host = (argc &gt; i) ? argv[i++] : <span class="stringliteral">&quot;&quot;</span>;</div><div class="line">  <span class="keyword">const</span> <span class="keywordtype">char</span> *port = (argc &gt; i) ? argv[i++] : <span class="stringliteral">&quot;amqp&quot;</span>;</div><div class="line"></div><div class="line">  <span class="comment">/* Listen on addr */</span></div><div class="line">  <span class="keywordtype">char</span> addr[<a name="a87"></a><a class="code" href="group__proactor.html#ga29ae114b42fb797c103dc9883ebcb256">PN_MAX_ADDR</a>];</div><div class="line">  <a name="a88"></a><a class="code" href="group__proactor.html#gaf67a7642c9003b36255b58776b494c96">pn_proactor_addr</a>(addr, <span class="keyword">sizeof</span>(addr), host, port);</div><div class="line">  <a name="a89"></a><a class="code" href="group__proactor.html#gacbed6a4ab75ef8452c10d52e4cd62752">pn_proactor_listen</a>(b.proactor, <a name="a90"></a><a class="code" href="group__listener.html#g
 abba0a7d2e916188e3ec07d0acf8f3fc5">pn_listener</a>(), addr, 16);</div><div class="line"></div><div class="line">  <span class="comment">/* Start n-1 threads */</span></div><div class="line">  pthread_t* threads = (pthread_t*)calloc(<span class="keyword">sizeof</span>(pthread_t), b.threads);</div><div class="line">  <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; b.threads-1; ++i) {</div><div class="line">    pthread_create(&amp;threads[i], NULL, broker_thread, &amp;b);</div><div class="line">  }</div><div class="line">  broker_thread(&amp;b);            <span class="comment">/* Use the main thread too. */</span></div><div class="line">  <span class="comment">/* Join the other threads */</span></div><div class="line">  <span class="keywordflow">for</span> (<span class="keywordtype">size_t</span> i = 0; i &lt; b.threads-1; ++i) {</div><div class="line">    pthread_join(threads[i], NULL);</div><div class="line">  }</div><div class="line">  <a
  name="a91"></a><a class="code" href="group__proactor.html#ga5260c2653d4af5eb2f1c8c6190e9d6cf">pn_proactor_free</a>(b.proactor);</div><div class="line">  free(threads);</div><div class="line">  <span class="keywordflow">return</span> exit_code;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/cid_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/cid_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/cid_8h_source.html
index c7eec7f..714b557 100755
--- a/content/releases/qpid-proton-master/proton/c/api/cid_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/cid_8h_source.html
@@ -3,7 +3,8 @@
 <head>
 <meta http-equiv="Content-Type" content="text/xhtml;charset=UTF-8"/>
 <meta http-equiv="X-UA-Compatible" content="IE=9"/>
-<meta name="generator" content="Doxygen 1.8.11"/>
+<meta name="generator" content="Doxygen 1.8.13"/>
+<meta name="viewport" content="width=device-width, initial-scale=1"/>
 <title>Qpid Proton C API: proton/cid.h Source File</title>
 <link href="tabs.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="jquery.js"></script>
@@ -14,7 +15,6 @@
 <script type="text/javascript" src="navtree.js"></script>
 <script type="text/javascript">
   $(document).ready(initResizable);
-  $(window).load(resizeHeight);
 </script>
 <link href="search/search.css" rel="stylesheet" type="text/css"/>
 <script type="text/javascript" src="search/searchdata.js"></script>
@@ -55,7 +55,7 @@
 </table>
 </div>
 <!-- end header part -->
-<!-- Generated by Doxygen 1.8.11 -->
+<!-- Generated by Doxygen 1.8.13 -->
 <script type="text/javascript">
 var searchBox = new SearchBox("searchBox", "search",false,'Search');
 </script>
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('cid_8h_source.html','');});
 <div class="title">cid.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CID_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CID_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008
 "></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span clas
 s="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</sp
 an>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;  CID_pn_object = 1,</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;  CID_pn_void,</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;  CID_pn_w
 eakref,</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;  CID_pn_string,</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;  CID_pn_list,</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;  CID_pn_map,</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;  CID_pn_hash,</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  CID_pn_record,</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  CID_pn_collector,</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;  CID_pn_event,</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></
 a><span class="lineno">   43</span>&#160;  CID_pn_encoder,</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;  CID_pn_decoder,</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;  CID_pn_data,</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;  CID_pn_connection,</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;  CID_pn_session,</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;  CID_pn_link,</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;  CID_pn_delivery,</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  CID_pn_transport,</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno
 ">   53</span>&#160;  CID_pn_message,</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  CID_pn_reactor,</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;  CID_pn_handler,</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  CID_pn_timer,</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;  CID_pn_task,</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;  CID_pn_io,</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;  CID_pn_selector,</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;  CID_pn_selectable,</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><
 div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;  CID_pn_url,</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;  CID_pn_listener,</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;  CID_pn_proactor</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;} pn_cid_t;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* cid.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents -->
+<div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_CID_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_CID_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008
 "></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span clas
 s="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</sp
 an>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="keyword">typedef</span> <span class="keyword">enum</span> {</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;  CID_pn_object = 1,</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;  CID_pn_void,</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;  CID_pn_w
 eakref,</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;  CID_pn_string,</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;  CID_pn_list,</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;  CID_pn_map,</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;  CID_pn_hash,</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  CID_pn_record,</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  CID_pn_collector,</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;  CID_pn_event,</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00043"></
 a><span class="lineno">   43</span>&#160;  CID_pn_encoder,</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;  CID_pn_decoder,</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;  CID_pn_data,</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;  CID_pn_connection,</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;  CID_pn_session,</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;  CID_pn_link,</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;  CID_pn_delivery,</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  CID_pn_transport,</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00053"></a><span class="lineno
 ">   53</span>&#160;  CID_pn_message,</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;  CID_pn_reactor,</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;  CID_pn_handler,</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;  CID_pn_timer,</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;  CID_pn_task,</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;  CID_pn_io,</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;  CID_pn_selector,</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;  CID_pn_selectable,</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><
 div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;  CID_pn_url,</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;  CID_pn_listener,</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;  CID_pn_proactor,</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;  CID_pn_listener_socket</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;} pn_cid_t;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* cid.h */</span><span class="preprocessor"></span></div></div><!-- fragment --></div><!-- contents 
 -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->
@@ -101,7 +101,7 @@ $(document).ready(function(){initNavTree('cid_8h_source.html','');});
     <li class="navelem"><a class="el" href="dir_25143d27009f52d175c1d192441a738a.html">proton</a></li><li class="navelem"><b>cid.h</b></li>
     <li class="footer">Generated by
     <a href="http://www.doxygen.org/index.html">
-    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.11 </li>
+    <img class="footer" src="doxygen.png" alt="doxygen"/></a> 1.8.13 </li>
   </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/codec_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/codec_8h.html b/content/releases/qpid-proton-master/proton/c/api/codec_8h.html
index 3841478..fa4dc1b 100755
--- a/content/releases/qpid-proton-master/proton/c/api/codec_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/codec_8h.html
@@ -113,7 +113,7 @@ $(document).ready(function(){initNavTree('codec_8h.html','');});
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="nested-classes"></a>
 Classes</h2></td></tr>
 <tr class="memitem:structpn__atom__t"><td class="memItemLeft" align="right" valign="top">struct &#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__api__types.html#structpn__atom__t">pn_atom_t</a></td></tr>
-<tr class="memdesc:structpn__atom__t"><td class="mdescLeft">&#160;</td><td class="mdescRight">A descriminated union that holds any scalar AMQP value.  <a href="group__api__types.html#structpn__atom__t">More...</a><br /></td></tr>
+<tr class="memdesc:structpn__atom__t"><td class="mdescLeft">&#160;</td><td class="mdescRight">A discriminated union that holds any scalar AMQP value.  <a href="group__api__types.html#structpn__atom__t">More...</a><br /></td></tr>
 <tr class="separator:structpn__atom__t"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table><table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="typedef-members"></a>
@@ -177,7 +177,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga68e94dfa5d7ab568425c4a6587bac1db"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error code for a given pn_data_t.  <a href="group__data.html#ga68e94dfa5d7ab568425c4a6587bac1db">More...</a><br /></td></tr>
 <tr class="separator:ga68e94dfa5d7ab568425c4a6587bac1db"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gada171f4740e6a1132b4d4b9c0aea645c"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__error.html#ga24a289d5b32c9bd8a775600a5af83d52">pn_error_t</a> *&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">pn_data_error</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
-<tr class="memdesc:gada171f4740e6a1132b4d4b9c0aea645c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error for a givn pn_data_t.  <a href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">More...</a><br /></td></tr>
+<tr class="memdesc:gada171f4740e6a1132b4d4b9c0aea645c"><td class="mdescLeft">&#160;</td><td class="mdescRight">Access the current error for a given pn_data_t.  <a href="group__data.html#gada171f4740e6a1132b4d4b9c0aea645c">More...</a><br /></td></tr>
 <tr class="separator:gada171f4740e6a1132b4d4b9c0aea645c"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga7611c1394e80b5166b8b8647659f97e6"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#ga7611c1394e80b5166b8b8647659f97e6">pn_data_clear</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
 <tr class="memdesc:ga7611c1394e80b5166b8b8647659f97e6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Clears a pn_data_t object.  <a href="group__data.html#ga7611c1394e80b5166b8b8647659f97e6">More...</a><br /></td></tr>
@@ -381,7 +381,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:gad03a049653bec28d20dc7587f7e544de"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a symbol, string, or binary, return the bytes representing its value.  <a href="group__data.html#gad03a049653bec28d20dc7587f7e544de">More...</a><br /></td></tr>
 <tr class="separator:gad03a049653bec28d20dc7587f7e544de"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gac5d5c6e6bf24597caf63d35b1755e646"><td class="memItemLeft" align="right" valign="top"><a class="el" href="group__api__types.html#structpn__atom__t">pn_atom_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gac5d5c6e6bf24597caf63d35b1755e646">pn_data_get_atom</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data)</td></tr>
-<tr class="memdesc:gac5d5c6e6bf24597caf63d35b1755e646"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A descriminated union that holds any scalar AMQP value. ">pn_atom_t</a>.  <a href="group__data.html#gac5d5c6e6bf24597caf63d35b1755e646">More...</a><br /></td></tr>
+<tr class="memdesc:gac5d5c6e6bf24597caf63d35b1755e646"><td class="mdescLeft">&#160;</td><td class="mdescRight">If the current node is a scalar value, return it as a <a class="el" href="group__api__types.html#structpn__atom__t" title="A discriminated union that holds any scalar AMQP value. ">pn_atom_t</a>.  <a href="group__data.html#gac5d5c6e6bf24597caf63d35b1755e646">More...</a><br /></td></tr>
 <tr class="separator:gac5d5c6e6bf24597caf63d35b1755e646"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gaf0e0fbb9c8c757f94b9636a6b54dc332"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332">pn_data_copy</a> (<a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *data, <a class="el" href="group__data.html#ga5d6cf528776e8b6ad6d67caf095986bf">pn_data_t</a> *src)</td></tr>
 <tr class="memdesc:gaf0e0fbb9c8c757f94b9636a6b54dc332"><td class="mdescLeft">&#160;</td><td class="mdescRight">Copy the contents of another pn_data_t object.  <a href="group__data.html#gaf0e0fbb9c8c757f94b9636a6b54dc332">More...</a><br /></td></tr>


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


[18/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.html
index a57b6c8..3022b79 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.html
@@ -104,12 +104,18 @@ $(document).ready(function(){initNavTree('classproton_1_1container.html','');});
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
-<tr class="memitem:a822ca363beceb76ffdc5ce370a4f9356"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a822ca363beceb76ffdc5ce370a4f9356">container</a> (<a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> &amp;handler, const std::string &amp;<a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677">id</a>=&quot;&quot;)</td></tr>
-<tr class="memdesc:a822ca363beceb76ffdc5ce370a4f9356"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container with a handler for messaging events.  <a href="#a822ca363beceb76ffdc5ce370a4f9356">More...</a><br /></td></tr>
-<tr class="separator:a822ca363beceb76ffdc5ce370a4f9356"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:aa73c3a48d397b513182a2d90ba5ab686"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#aa73c3a48d397b513182a2d90ba5ab686">container</a> (const std::string &amp;<a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677">id</a>=&quot;&quot;)</td></tr>
-<tr class="memdesc:aa73c3a48d397b513182a2d90ba5ab686"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container.  <a href="#aa73c3a48d397b513182a2d90ba5ab686">More...</a><br /></td></tr>
-<tr class="separator:aa73c3a48d397b513182a2d90ba5ab686"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a9a322df81c8d397bb4c3fa6c1a67a496"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a9a322df81c8d397bb4c3fa6c1a67a496">container</a> (<a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> &amp;handler, const std::string &amp;<a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677">id</a>)</td></tr>
+<tr class="memdesc:a9a322df81c8d397bb4c3fa6c1a67a496"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container with a global handler for messaging events.  <a href="#a9a322df81c8d397bb4c3fa6c1a67a496">More...</a><br /></td></tr>
+<tr class="separator:a9a322df81c8d397bb4c3fa6c1a67a496"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a3d7f4be6b8ace086ed7470f66a742059"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a3d7f4be6b8ace086ed7470f66a742059">container</a> (<a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> &amp;handler)</td></tr>
+<tr class="memdesc:a3d7f4be6b8ace086ed7470f66a742059"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container with a global handler for messaging events.  <a href="#a3d7f4be6b8ace086ed7470f66a742059">More...</a><br /></td></tr>
+<tr class="separator:a3d7f4be6b8ace086ed7470f66a742059"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a88125a4442a7b28fab97a89587627c0f"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a88125a4442a7b28fab97a89587627c0f">container</a> (const std::string &amp;<a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677">id</a>)</td></tr>
+<tr class="memdesc:a88125a4442a7b28fab97a89587627c0f"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container.  <a href="#a88125a4442a7b28fab97a89587627c0f">More...</a><br /></td></tr>
+<tr class="separator:a88125a4442a7b28fab97a89587627c0f"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:aeacc0140de439ebab9a5466c45d38191"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#aeacc0140de439ebab9a5466c45d38191">container</a> ()</td></tr>
+<tr class="memdesc:aeacc0140de439ebab9a5466c45d38191"><td class="mdescLeft">&#160;</td><td class="mdescRight">Create a container.  <a href="#aeacc0140de439ebab9a5466c45d38191">More...</a><br /></td></tr>
+<tr class="separator:aeacc0140de439ebab9a5466c45d38191"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a7c64e64cedfa36303be53f0f581d1d24"><td class="memItemLeft" align="right" valign="top">&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a7c64e64cedfa36303be53f0f581d1d24">~container</a> ()</td></tr>
 <tr class="memdesc:a7c64e64cedfa36303be53f0f581d1d24"><td class="mdescLeft">&#160;</td><td class="mdescRight">Destroy a container.  <a href="#a7c64e64cedfa36303be53f0f581d1d24">More...</a><br /></td></tr>
 <tr class="separator:a7c64e64cedfa36303be53f0f581d1d24"><td class="memSeparator" colspan="2">&#160;</td></tr>
@@ -132,7 +138,7 @@ Public Member Functions</h2></td></tr>
 <tr class="memdesc:a13a43e6d814de94978c515cb084873b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">Run the container in the current thread.  <a href="#a13a43e6d814de94978c515cb084873b1">More...</a><br /></td></tr>
 <tr class="separator:a13a43e6d814de94978c515cb084873b1"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ac48e94529e54c7e7342fde28b26d9f48"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#ac48e94529e54c7e7342fde28b26d9f48">run</a> (int count)</td></tr>
-<tr class="memdesc:ac48e94529e54c7e7342fde28b26d9f48"><td class="mdescLeft">&#160;</td><td class="mdescRight">Run the container with a pool of <code>count</code> threads.  <a href="#ac48e94529e54c7e7342fde28b26d9f48">More...</a><br /></td></tr>
+<tr class="memdesc:ac48e94529e54c7e7342fde28b26d9f48"><td class="mdescLeft">&#160;</td><td class="mdescRight">Run the container with a pool of <code>count</code> threads, including the current thread.  <a href="#ac48e94529e54c7e7342fde28b26d9f48">More...</a><br /></td></tr>
 <tr class="separator:ac48e94529e54c7e7342fde28b26d9f48"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a1d5932054f172c66000aec9f4ed498df"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a1d5932054f172c66000aec9f4ed498df">auto_stop</a> (bool enabled)</td></tr>
 <tr class="memdesc:a1d5932054f172c66000aec9f4ed498df"><td class="mdescLeft">&#160;</td><td class="mdescRight">Enable or disable automatic container stop.  <a href="#a1d5932054f172c66000aec9f4ed498df">More...</a><br /></td></tr>
@@ -195,18 +201,22 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <tr class="memitem:a099ddaa3cfcd6a8ae14401bbbfb4b660"><td class="memItemLeft" align="right" valign="top">class <a class="el" href="classproton_1_1receiver__options.html">receiver_options</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a099ddaa3cfcd6a8ae14401bbbfb4b660">receiver_options</a> () const</td></tr>
 <tr class="memdesc:a099ddaa3cfcd6a8ae14401bbbfb4b660"><td class="mdescLeft">&#160;</td><td class="mdescRight">Receiver options applied to receivers created by this container.  <a href="#a099ddaa3cfcd6a8ae14401bbbfb4b660">More...</a><br /></td></tr>
 <tr class="separator:a099ddaa3cfcd6a8ae14401bbbfb4b660"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:aa99ede2051ccdf5fe8257d893559ea26"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a> dur, <a class="el" href="classproton_1_1work.html">work</a> fn)</td></tr>
+<tr class="memitem:aa99ede2051ccdf5fe8257d893559ea26"><td class="memItemLeft" align="right" valign="top">void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a> dur, work fn)</td></tr>
 <tr class="memdesc:aa99ede2051ccdf5fe8257d893559ea26"><td class="mdescLeft">&#160;</td><td class="mdescRight">Schedule <code>fn</code> for execution after a duration.  <a href="#aa99ede2051ccdf5fe8257d893559ea26">More...</a><br /></td></tr>
 <tr class="separator:aa99ede2051ccdf5fe8257d893559ea26"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a3e20a15733ef55ac0c43fbe1e60813d4"><td class="memItemLeft" align="right" valign="top"><a id="a3e20a15733ef55ac0c43fbe1e60813d4"></a>
+void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1container.html#a3e20a15733ef55ac0c43fbe1e60813d4">schedule</a> (<a class="el" href="classproton_1_1duration.html">duration</a> dur, void_function0 &amp;fn)</td></tr>
+<tr class="memdesc:a3e20a15733ef55ac0c43fbe1e60813d4"><td class="mdescLeft">&#160;</td><td class="mdescRight"><b>Deprecated</b> - Use <code><a class="el" href="classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26" title="Schedule fn for execution after a duration. ">container::schedule(duration, work)</a></code>. <br /></td></tr>
+<tr class="separator:a3e20a15733ef55ac0c43fbe1e60813d4"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A top-level container of connections, sessions, and links. </p>
 <p>A container gives a unique identity to each communicating peer. It is often a process-level object.</p>
 <p>It also serves as an entry point to the API, allowing connections, senders, and receivers to be established. It can be supplied with an event handler in order to intercept important messaging events, such as newly received messages or newly issued credit for sending messages. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a10">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a6">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a3">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a3">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a3">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a3">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a9">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a3">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a6">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a5">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#_a4">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a2">server_di
 rect.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a8">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#_a3">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a3">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a9">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a6">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a4">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a4">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a2">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a9">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a3">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#_a6">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#_a5">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#_a3">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a4">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a8">service_bus.cpp</a>,
  <a class="el" href="simple_recv_8cpp-example.html#_a3">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#_a3">simple_send.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
-<a id="a822ca363beceb76ffdc5ce370a4f9356"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a822ca363beceb76ffdc5ce370a4f9356">&#9670;&nbsp;</a></span>container() <span class="overload">[1/2]</span></h2>
+<a id="a9a322df81c8d397bb4c3fa6c1a67a496"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a9a322df81c8d397bb4c3fa6c1a67a496">&#9670;&nbsp;</a></span>container() <span class="overload">[1/4]</span></h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -221,7 +231,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
           <td class="paramkey"></td>
           <td></td>
           <td class="paramtype">const std::string &amp;&#160;</td>
-          <td class="paramname"><em>id</em> = <code>&quot;&quot;</code>&#160;</td>
+          <td class="paramname"><em>id</em>&#160;</td>
         </tr>
         <tr>
           <td></td>
@@ -231,13 +241,47 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
       </table>
 </div><div class="memdoc">
 
-<p>Create a container with a handler for messaging events. </p>
-<p>The optional <code>id</code> parameter sets the container's unique identity. </p>
+<p>Create a container with a global handler for messaging events. </p>
+<p><b>Thread safety</b> - in a multi-threaded container this handler will be called concurrently. You can use locks to make that safe, or use a separate handler for each connection. See <a class="el" href="mt_page.html">Multithreading</a>.</p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramname">handler</td><td>global handler, called for events on all connections managed by the container.</td></tr>
+    <tr><td class="paramname">id</td><td>sets the container's unique identity. </td></tr>
+  </table>
+  </dd>
+</dl>
 
 </div>
 </div>
-<a id="aa73c3a48d397b513182a2d90ba5ab686"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#aa73c3a48d397b513182a2d90ba5ab686">&#9670;&nbsp;</a></span>container() <span class="overload">[2/2]</span></h2>
+<a id="a3d7f4be6b8ace086ed7470f66a742059"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a3d7f4be6b8ace086ed7470f66a742059">&#9670;&nbsp;</a></span>container() <span class="overload">[2/4]</span></h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname"><a class="el" href="classproton_1_1container.html">container</a> </td>
+          <td>(</td>
+          <td class="paramtype"><a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> &amp;&#160;</td>
+          <td class="paramname"><em>handler</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Create a container with a global handler for messaging events. </p>
+<p><b>Thread safety</b> - in a multi-threaded container this handler will be called concurrently. You can use locks to make that safe, or use a separate handler for each connection. See <a class="el" href="mt_page.html">Multithreading</a>.</p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramname">handler</td><td>global handler, called for events on all connections managed by the container. </td></tr>
+  </table>
+  </dd>
+</dl>
+
+</div>
+</div>
+<a id="a88125a4442a7b28fab97a89587627c0f"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a88125a4442a7b28fab97a89587627c0f">&#9670;&nbsp;</a></span>container() <span class="overload">[3/4]</span></h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -246,14 +290,39 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
           <td class="memname"><a class="el" href="classproton_1_1container.html">container</a> </td>
           <td>(</td>
           <td class="paramtype">const std::string &amp;&#160;</td>
-          <td class="paramname"><em>id</em> = <code>&quot;&quot;</code></td><td>)</td>
+          <td class="paramname"><em>id</em></td><td>)</td>
+          <td></td>
+        </tr>
+      </table>
+</div><div class="memdoc">
+
+<p>Create a container. </p>
+<dl class="params"><dt>Parameters</dt><dd>
+  <table class="params">
+    <tr><td class="paramname">id</td><td>sets the container's unique identity. </td></tr>
+  </table>
+  </dd>
+</dl>
+
+</div>
+</div>
+<a id="aeacc0140de439ebab9a5466c45d38191"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#aeacc0140de439ebab9a5466c45d38191">&#9670;&nbsp;</a></span>container() <span class="overload">[4/4]</span></h2>
+
+<div class="memitem">
+<div class="memproto">
+      <table class="memname">
+        <tr>
+          <td class="memname"><a class="el" href="classproton_1_1container.html">container</a> </td>
+          <td>(</td>
+          <td class="paramname"></td><td>)</td>
           <td></td>
         </tr>
       </table>
 </div><div class="memdoc">
 
 <p>Create a container. </p>
-<p>The optional <code>id</code> parameter sets the container's unique identity. </p>
+<p>This will create a default random identity </p>
 
 </div>
 </div>
@@ -273,7 +342,8 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Destroy a container. </p>
-<p><b>Thread safety</b> - It is unsafe to delete a container from within any of the threads running a <code><a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">messaging_handler</a></code>. Deleting the container from within a handler will cause a deadlock or crash. The only safe place to delete a container is after all of the threads running a container have finished and all of the <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a></code> functions have returned. </p>
+<p>A container must not be destroyed while a call to <a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a> is in progress, in particular it must not be destroyed from a <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> callback.</p>
+<p><b>Thread safety</b> - in a multi-threaded application, <a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a> must return in all threads that call it before destroying the container. </p>
 
 </div>
 </div>
@@ -310,9 +380,9 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <li><a class="el" href="classproton_1_1container.html#a913a88786abbbf08dd3e53e2a3e4accb" title="Connection options applied to outgoing connections. ">client_connection_options()</a></li>
 <li>Options passed to <a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">connect()</a></li>
 </ol>
-<p>Values in later options override earlier ones. The handler in the composed options is used to call <code><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code> when the open response is received from the remote peer.</p>
+<p>Values in later options override earlier ones. The handler in the composed options is used to call <code><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code> when the open response is received from the remote peer.</p>
 <p><b>Thread safety</b> - Container method return values are <em>thread-unsafe</em>. A single-threaded application can safely assign the <code>returned&lt;T&gt;</code> value to a plain <code>T</code>. A multithreaded application <em>must</em> ignore the returned value because it may already be invalid by the time the function returns. Multithreaded applications can safely access the value inside <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> functions. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="helloworld_8cpp-example.html#a4">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a10">multithreaded_client.cpp</a>, <a class="el" href="server_8cpp-example.html#a5">server.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#a10">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="helloworld_8cpp-example.html#a3">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a10">multithreaded_client.cpp</a>, <a class="el" href="server_8cpp-example.html#a4">server.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#a10">service_bus.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -364,8 +434,10 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Listen for new connections on <code>listen_url</code>. </p>
-<p><b>Thread safety</b> - Calls to <code><a class="el" href="classproton_1_1listen__handler.html" title="Unsettled API - A handler for incoming connections. ">listen_handler</a></code> methods are serialized for this listener, but handlers attached to separate listeners can be safely called concurrently. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a26">broker.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a4">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a4">direct_send.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a4">helloworld_direct.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#a3">server_direct.cpp</a>.</dd>
+<p>If the listener opens successfully, <a class="el" href="classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b" title="Called when the listener is opened successfully. ">listen_handler::on_open()</a> is called. If it fails to open, <a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53" title="Called if there is a listening error, with an error message. ">listen_handler::on_error()</a> then listen_handler::close() are called.</p>
+<p><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc" title="Called for each accepted connection. ">listen_handler::on_accept()</a> is called for each incoming connection to determine the <a class="el" href="classproton_1_1connection__options.html">connection_options</a> to use, including the <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a>.</p>
+<p><b>Thread safety</b> - Calls to <code><a class="el" href="classproton_1_1listen__handler.html" title="Unsettled API - A handler for incoming connections. ">listen_handler</a></code> methods are serialized for this listener, but handlers attached to separate listeners may be called concurrently. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a5">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a5">direct_send.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#a5">server_direct.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -396,7 +468,8 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Listen for new connections on <code>listen_url</code>. </p>
-<p>Use a fixed set of options for all accepted connections. See <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen(const std::string&amp;, listen_handler&amp;)</a>. </p>
+<p>Use a fixed set of options for all accepted connections. See <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen(const std::string&amp;, listen_handler&amp;)</a>.</p>
+<p><b>Thread safety</b> - for multi-threaded applications we recommend using a <a class="el" href="classproton_1_1listen__handler.html">listen_handler</a> to create a new <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> for each connection. See <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen(const std::string&amp;, listen_handler&amp;)</a> and <a class="el" href="mt_page.html">Multithreading</a> </p>
 
 </div>
 </div>
@@ -417,7 +490,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Listen for new connections on <code>listen_url</code>. </p>
-<p>New connections will use the handler from <code><a class="el" href="classproton_1_1container.html#a7daf70330e5259fbb6ae3f01cfbc125a" title="Connection options applied to incoming connections. ">server_connection_options()</a></code>. </p>
+<p>New connections will use the handler from <code><a class="el" href="classproton_1_1container.html#a7daf70330e5259fbb6ae3f01cfbc125a" title="Connection options applied to incoming connections. ">server_connection_options()</a></code>. See listen(const std::string&amp;, const <a class="el" href="classproton_1_1connection__options.html" title="Options for creating a connection. ">connection_options</a>&amp;); </p>
 
 </div>
 </div>
@@ -438,8 +511,8 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 
 <p>Run the container in the current thread. </p>
 <p>The call returns when the container stops. See <code><a class="el" href="classproton_1_1container.html#a1d5932054f172c66000aec9f4ed498df" title="Enable or disable automatic container stop. ">auto_stop()</a></code> and <code><a class="el" href="classproton_1_1container.html#a8c528baf37154d347366083f0f816846" title="Stop the container with an empty error condition. ">stop()</a></code>.</p>
-<p><b>C++ versions</b> - With C++11 or later, you can call <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a></code> in multiple threads to create a thread pool. See also <code><a class="el" href="classproton_1_1container.html#ac48e94529e54c7e7342fde28b26d9f48" title="Run the container with a pool of count threads. ">run(int count)</a></code>. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a27">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#a21">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a15">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a19">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a20">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a19">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a21">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a22">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a19">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a17">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#a17">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#a19">server_dir
 ect.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a29">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a17">simple_recv.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a20">simple_send.cpp</a>.</dd>
+<p><b>C++ versions</b> - With C++11 or later, you can call <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a></code> in multiple threads to create a thread pool. See also <code><a class="el" href="classproton_1_1container.html#ac48e94529e54c7e7342fde28b26d9f48" title="Run the container with a pool of count threads, including the current thread. ">run(int count)</a></code>. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a21">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#a15">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#a17">direct_send.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a18">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#a21">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a22">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a19">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a17">scheduled_send_03.cpp</a>, <a class="el" href="server_8cpp-example.html#a14">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#a19">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a32">service_bus.cpp</a>, <a class="el" href="simple_recv_8cpp-example.html#a17">simple_rec
 v.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a20">simple_send.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -459,7 +532,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
       </table>
 </div><div class="memdoc">
 
-<p>Run the container with a pool of <code>count</code> threads. </p>
+<p>Run the container with a pool of <code>count</code> threads, including the current thread. </p>
 <p><b>C++ versions</b> - Available with C++11 or later.</p>
 <p>The call returns when the container stops. See <code><a class="el" href="classproton_1_1container.html#a1d5932054f172c66000aec9f4ed498df" title="Enable or disable automatic container stop. ">auto_stop()</a></code> and <code><a class="el" href="classproton_1_1container.html#a8c528baf37154d347366083f0f816846" title="Stop the container with an empty error condition. ">stop()</a></code>. </p>
 
@@ -508,11 +581,12 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <ul>
 <li>Abort all open connections and listeners.</li>
 <li>Process final handler events and queued work.</li>
-<li>If <code>!err.empty()</code>, fire <code><a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error</a></code>.</li>
+<li>If <code>!err.empty()</code>, fire <code><a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error</a></code>.</li>
 </ul>
 <p>When the process is complete, <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a></code> returns in all threads.</p>
-<p><b>Thread safety</b> - It is safe to call this method across threads. </p>
-
+<p><b>Thread safety</b> - It is safe to call this method in any thread. </p>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#a26">broker.cpp</a>.</dd>
+</dl>
 </div>
 </div>
 <a id="a8c528baf37154d347366083f0f816846"></a>
@@ -535,10 +609,10 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <ul>
 <li>Abort all open connections and listeners.</li>
 <li>Process final handler events and queued work.</li>
-<li>If <code>!err.empty()</code>, fire <code><a class="el" href="classproton_1_1messaging__handler.html#af89551ce0e44ae3465d4b078f1c87653" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error</a></code>.</li>
+<li>If <code>!err.empty()</code>, fire <code><a class="el" href="classproton_1_1messaging__handler.html#ab719e98555bab69986acf4ab1fe43665" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error</a></code>.</li>
 </ul>
 <p>When the process is complete, <code><a class="el" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1" title="Run the container in the current thread. ">run()</a></code> returns in all threads.</p>
-<p><b>Thread safety</b> - It is safe to call this method across threads. </p>
+<p><b>Thread safety</b> - It is safe to call this method in any thread. </p>
 
 </div>
 </div>
@@ -560,7 +634,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 
 <p>Open a connection and sender for <code>addr_url</code>. </p>
 <p><b>Thread safety</b> - Container method return values are <em>thread-unsafe</em>. A single-threaded application can safely assign the <code>returned&lt;T&gt;</code> value to a plain <code>T</code>. A multithreaded application <em>must</em> ignore the returned value because it may already be invalid by the time the function returns. Multithreaded applications can safely access the value inside <a class="el" href="classproton_1_1messaging__handler.html">messaging_handler</a> functions. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a7">client.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a5">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a4">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a7">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a6">scheduled_send_03.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a23">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a7">simple_send.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="client_8cpp-example.html#a7">client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#a4">multithreaded_client_flow_control.cpp</a>, <a class="el" href="scheduled_send_8cpp-example.html#a7">scheduled_send.cpp</a>, <a class="el" href="scheduled_send_03_8cpp-example.html#a6">scheduled_send_03.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a26">service_bus.cpp</a>, and <a class="el" href="simple_send_8cpp-example.html#a7">simple_send.cpp</a>.</dd>
 </dl>
 </div>
 </div>
@@ -807,7 +881,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Connection options applied to outgoing connections. </p>
-<p>These are applied first and then overriden by any options provided in <code><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">connect()</a></code> or <code><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
+<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">connect()</a></code> or <code><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
 
 </div>
 </div>
@@ -827,7 +901,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Connection options applied to outgoing connections. </p>
-<p>These are applied first and then overriden by any options provided in <code><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">connect()</a></code> or <code><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
+<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1" title="Connect to conn_url and send an open request to the remote peer. ">connect()</a></code> or <code><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
 
 </div>
 </div>
@@ -848,7 +922,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Connection options applied to incoming connections. </p>
-<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen()</a></code>, <code><a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b" title="Called for each accepted connection. ">listen_handler::on_accept()</a></code>, or <code><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
+<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen()</a></code>, <code><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc" title="Called for each accepted connection. ">listen_handler::on_accept()</a></code>, or <code><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
 
 </div>
 </div>
@@ -868,7 +942,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Connection options applied to incoming connections. </p>
-<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen()</a></code>, <code><a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b" title="Called for each accepted connection. ">listen_handler::on_accept()</a></code>, or <code><a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
+<p>These are applied first and then overridden by any options provided in <code><a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">listen()</a></code>, <code><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc" title="Called for each accepted connection. ">listen_handler::on_accept()</a></code>, or <code><a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a></code>. </p>
 
 </div>
 </div>
@@ -889,7 +963,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Sender options applied to senders created by this container. </p>
-<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661" title="The remote peer opened the link. ">messaging_handler::on_sender_open()</a></code> and can be overridden. </p>
+<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4" title="The remote peer opened the link. ">messaging_handler::on_sender_open()</a></code> and can be overridden. </p>
 
 </div>
 </div>
@@ -909,7 +983,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Sender options applied to senders created by this container. </p>
-<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a0b5d066e5463d3365f662c8a7dc52661" title="The remote peer opened the link. ">messaging_handler::on_sender_open()</a></code> and can be overridden. </p>
+<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#ac655d56c64574c9eb7b10e80d32764f4" title="The remote peer opened the link. ">messaging_handler::on_sender_open()</a></code> and can be overridden. </p>
 
 </div>
 </div>
@@ -930,7 +1004,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Receiver options applied to receivers created by this container. </p>
-<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd" title="The remote peer opened the link. ">messaging_handler::on_receiver_open()</a></code> and can be overridden. </p>
+<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401" title="The remote peer opened the link. ">messaging_handler::on_receiver_open()</a></code> and can be overridden. </p>
 
 </div>
 </div>
@@ -950,7 +1024,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </div><div class="memdoc">
 
 <p>Receiver options applied to receivers created by this container. </p>
-<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a768b0a50669aa1d512d12e9d68af14cd" title="The remote peer opened the link. ">messaging_handler::on_receiver_open()</a></code> and can be overridden. </p>
+<p>They are applied before <code><a class="el" href="classproton_1_1messaging__handler.html#a77f7e38659ee43ccb764e417ad6dd401" title="The remote peer opened the link. ">messaging_handler::on_receiver_open()</a></code> and can be overridden. </p>
 
 </div>
 </div>
@@ -969,7 +1043,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
         <tr>
           <td class="paramkey"></td>
           <td></td>
-          <td class="paramtype"><a class="el" href="classproton_1_1work.html">work</a>&#160;</td>
+          <td class="paramtype">work&#160;</td>
           <td class="paramname"><em>fn</em>&#160;</td>
         </tr>
         <tr>
@@ -983,7 +1057,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 <p>Schedule <code>fn</code> for execution after a duration. </p>
 <p>The piece of work can be created from a function object.</p>
 <p><b>C++ versions</b> - With C++11 and later, use a <code>std::function&lt;void()&gt;</code> type for the <code>fn</code> parameter. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="scheduled_send_8cpp-example.html#a11">scheduled_send.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#a16">service_bus.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="scheduled_send_8cpp-example.html#a11">scheduled_send.cpp</a>, and <a class="el" href="service_bus_8cpp-example.html#a17">service_bus.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.js
index 3cde08a..974abec 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1container.js
@@ -1,7 +1,9 @@
 var classproton_1_1container =
 [
-    [ "container", "classproton_1_1container.html#a822ca363beceb76ffdc5ce370a4f9356", null ],
-    [ "container", "classproton_1_1container.html#aa73c3a48d397b513182a2d90ba5ab686", null ],
+    [ "container", "classproton_1_1container.html#a9a322df81c8d397bb4c3fa6c1a67a496", null ],
+    [ "container", "classproton_1_1container.html#a3d7f4be6b8ace086ed7470f66a742059", null ],
+    [ "container", "classproton_1_1container.html#a88125a4442a7b28fab97a89587627c0f", null ],
+    [ "container", "classproton_1_1container.html#aeacc0140de439ebab9a5466c45d38191", null ],
     [ "~container", "classproton_1_1container.html#a7c64e64cedfa36303be53f0f581d1d24", null ],
     [ "connect", "classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1", null ],
     [ "connect", "classproton_1_1container.html#a422bf1e05b6a01039f0ef603b2f165a4", null ],
@@ -30,5 +32,6 @@ var classproton_1_1container =
     [ "sender_options", "classproton_1_1container.html#ae7bfc8d811be7f6be17be6cf15e35b4a", null ],
     [ "receiver_options", "classproton_1_1container.html#a2e01779c75286d270f579a28dae14d37", null ],
     [ "receiver_options", "classproton_1_1container.html#a099ddaa3cfcd6a8ae14401bbbfb4b660", null ],
-    [ "schedule", "classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26", null ]
+    [ "schedule", "classproton_1_1container.html#aa99ede2051ccdf5fe8257d893559ea26", null ],
+    [ "schedule", "classproton_1_1container.html#a3e20a15733ef55ac0c43fbe1e60813d4", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1delivery.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1delivery.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1delivery.html
index 306fced..419b4a3 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1delivery.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1delivery.html
@@ -181,7 +181,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>A received message. </p>
 <p>A delivery attempt can fail. As a result, a particular message may correspond to multiple deliveries. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a16">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a18">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a6">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a16">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#_a12">helloworld_direct.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a18">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a21">multithreaded_client_flow_control.cpp</a>, <a class="el" href="server_8cpp-example.html#_a9">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a12">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a18">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#_a9">simple_recv.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a14">broker.cpp</a>, <a class="el" href="client_8cpp-example.html#_a18">client.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a6">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#_a14">helloworld.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a18">multithreaded_client.cpp</a>, <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a21">multithreaded_client_flow_control.cpp</a>, <a class="el" href="server_8cpp-example.html#_a7">server.cpp</a>, <a class="el" href="server_direct_8cpp-example.html#_a12">server_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#_a21">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#_a9">simple_recv.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Enumeration Documentation</h2>
 <a id="adc6e5733fc3c22f0a7b2914188c49c90"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#adc6e5733fc3c22f0a7b2914188c49c90">&#9670;&nbsp;</a></span>state</h2>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration-members.html
index 51df64a..ac8e3ef 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration-members.html
@@ -99,11 +99,12 @@ $(document).ready(function(){initNavTree('classproton_1_1duration.html','');});
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#aa4fb0163afbe72b04236e39e2b6d2dbf">duration</a>(numeric_type ms=0)</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">inline</span><span class="mlabel">explicit</span></td></tr>
   <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#acebdd3ee364870f89665ca128e97a4d7">FOREVER</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#ab804de8e95dd6203d6e72e797440055e">IMMEDIATE</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() const</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">MINUTE</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">numeric_type</a> typedef</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">operator=</a>(numeric_type ms)</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">SECOND</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">MILLISECOND</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#afb6516c796d13a88dcbd295247f0f535">milliseconds</a>() const</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">MINUTE</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#a44829e89515fec974f57f37bbdbfaeb2">numeric_type</a> typedef</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1duration.html#a13ff6465e0979fe301b75ea574ce2304">operator=</a>(numeric_type ms)</td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">inline</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">SECOND</a></td><td class="entry"><a class="el" href="classproton_1_1duration.html">duration</a></td><td class="entry"><span class="mlabel">static</span></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration.html
index 193c0df..52c0002 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1duration.html
@@ -148,6 +148,10 @@ static const <a class="el" href="classproton_1_1duration.html">duration</a>&#160
 static const <a class="el" href="classproton_1_1duration.html">duration</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1duration.html#aced1c394edccf069b2748d46965fb562">SECOND</a></td></tr>
 <tr class="memdesc:aced1c394edccf069b2748d46965fb562"><td class="mdescLeft">&#160;</td><td class="mdescRight">One second. <br /></td></tr>
 <tr class="separator:aced1c394edccf069b2748d46965fb562"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:ad936986f8cf9cb95b0dbc93ade000b76"><td class="memItemLeft" align="right" valign="top"><a id="ad936986f8cf9cb95b0dbc93ade000b76"></a>
+static const <a class="el" href="classproton_1_1duration.html">duration</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1duration.html#ad936986f8cf9cb95b0dbc93ade000b76">MILLISECOND</a></td></tr>
+<tr class="memdesc:ad936986f8cf9cb95b0dbc93ade000b76"><td class="mdescLeft">&#160;</td><td class="mdescRight">One millisecond. <br /></td></tr>
+<tr class="separator:ad936986f8cf9cb95b0dbc93ade000b76"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a437a5e5f6a7d0c8780f3594b2272cba0"><td class="memItemLeft" align="right" valign="top"><a id="a437a5e5f6a7d0c8780f3594b2272cba0"></a>
 static const <a class="el" href="classproton_1_1duration.html">duration</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1duration.html#a437a5e5f6a7d0c8780f3594b2272cba0">MINUTE</a></td></tr>
 <tr class="memdesc:a437a5e5f6a7d0c8780f3594b2272cba0"><td class="mdescLeft">&#160;</td><td class="mdescRight">One minute. <br /></td></tr>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1error__condition.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1error__condition.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1error__condition.html
index e2fb2e7..29d08ee 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1error__condition.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1error__condition.html
@@ -148,7 +148,7 @@ std::string&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hre
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p>Describes an endpoint error state. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a23">broker.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a20">multithreaded_client.cpp</a>, and <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a16">multithreaded_client_flow_control.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a27">broker.cpp</a>, <a class="el" href="multithreaded_client_8cpp-example.html#_a20">multithreaded_client.cpp</a>, and <a class="el" href="multithreaded_client_flow_control_8cpp-example.html#_a16">multithreaded_client_flow_control.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Constructor &amp; Destructor Documentation</h2>
 <a id="a4f32954b9494f55fa28e99c3402f254b"></a>
 <h2 class="memtitle"><span class="permalink"><a href="#a4f32954b9494f55fa28e99c3402f254b">&#9670;&nbsp;</a></span>error_condition() <span class="overload">[1/2]</span></h2>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1io_1_1connection__driver.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1io_1_1connection__driver.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1io_1_1connection__driver.html
index 28c3b47..728bb1c 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1io_1_1connection__driver.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1io_1_1connection__driver.html
@@ -243,7 +243,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 
 <p>Call <a class="el" href="classproton_1_1io_1_1connection__driver.html#a86d2b78bee258ce7bb56806d11a122d3" title="Configure a connection by applying exactly the options in opts (including proton::messaging_handler) ...">configure()</a> with server options. </p>
 <p>Options applied: <a class="el" href="classproton_1_1container.html#a4c5cdd8165762b000c6518db56830677" title="A unique identifier for the container. ">container::id()</a>, <a class="el" href="classproton_1_1container.html#a7daf70330e5259fbb6ae3f01cfbc125a" title="Connection options applied to incoming connections. ">container::server_connection_options()</a>, opts.</p>
-<p>Note this does not call <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a>. If there is a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">messaging_handler</a> in the composed options it will receive <a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a> and can respond with <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a> or <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca" title="Close the endpoint. ">connection::close()</a> </p>
+<p>Note this does not call <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a>. If there is a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">messaging_handler</a> in the composed options it will receive <a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a> and can respond with <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a> or <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca" title="Close the endpoint. ">connection::close()</a> </p>
 
 </div>
 </div>
@@ -407,7 +407,7 @@ bool&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="clas
 </div><div class="memdoc">
 
 <p>Inform the engine that the transport been disconnected unexpectedly, without completing the AMQP connection close sequence. </p>
-<p>This calls <a class="el" href="classproton_1_1io_1_1connection__driver.html#aaa622a6fed072f5b4935881efb42ba5c" title="Indicate that the read side of the transport is closed and no more data will be read. ">read_close()</a>, <a class="el" href="classproton_1_1io_1_1connection__driver.html#ad730a1d850ea31f35102b765d0eede4a" title="Indicate that the write side of the transport has closed and no more data can be written. ">write_close()</a>, sets the <a class="el" href="classproton_1_1io_1_1connection__driver.html#ae6bd8677ca01c17bc04d6064bbc2c394" title="Get the transport associated with this connection_driver. ">transport()</a>.error() and queues an <code>on_transport_error</code> event. You must call <a class="el" href="classproton_1_1io_1_1connection__driver.html#a4c79ad1c9029d967b9e1b4daf91b7537" title="Dispatch all available events and call the corresponding messaging_handler methods. ">dispatch()</a> one more time to dispatch the <a class="el" href="classproton_1_1messaging__h
 andler.html#af89551ce0e44ae3465d4b078f1c87653" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error()</a> call and other final events.</p>
+<p>This calls <a class="el" href="classproton_1_1io_1_1connection__driver.html#aaa622a6fed072f5b4935881efb42ba5c" title="Indicate that the read side of the transport is closed and no more data will be read. ">read_close()</a>, <a class="el" href="classproton_1_1io_1_1connection__driver.html#ad730a1d850ea31f35102b765d0eede4a" title="Indicate that the write side of the transport has closed and no more data can be written. ">write_close()</a>, sets the <a class="el" href="classproton_1_1io_1_1connection__driver.html#ae6bd8677ca01c17bc04d6064bbc2c394" title="Get the transport associated with this connection_driver. ">transport()</a>.error() and queues an <code>on_transport_error</code> event. You must call <a class="el" href="classproton_1_1io_1_1connection__driver.html#a4c79ad1c9029d967b9e1b4daf91b7537" title="Dispatch all available events and call the corresponding messaging_handler methods. ">dispatch()</a> one more time to dispatch the <a class="el" href="classproton_1_1messaging__h
 andler.html#ab719e98555bab69986acf4ab1fe43665" title="The underlying network transport has closed with an error condition. ">messaging_handler::on_transport_error()</a> call and other final events.</p>
 <p>Note this does not close the <a class="el" href="classproton_1_1io_1_1connection__driver.html#a8239782294f4dacf38c46a2640e55bf0" title="Get the AMQP connection associated with this connection_driver. ">connection()</a> so that a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a> can distinguish between a connection close error sent by the remote peer and a transport failure. </p>
 
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1link.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1link.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1link.html
index 7f0a924..113f517 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1link.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1link.html
@@ -203,7 +203,7 @@ class <a class="el" href="classproton_1_1session.html">session</a>&#160;</td><td
 <dl class="section see"><dt>See also</dt><dd>endpoint_lifecycle </dd></dl>
 
 <p>Implements <a class="el" href="classproton_1_1endpoint.html#af6ee7eacbde6b379b68d954e44f6e549">endpoint</a>.</p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a14">helloworld.cpp</a>, <a class="el" href="helloworld_direct_8cpp-example.html#a10">helloworld_direct.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a20">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="direct_recv_8cpp-example.html#a11">direct_recv.cpp</a>, <a class="el" href="helloworld_8cpp-example.html#a12">helloworld.cpp</a>, <a class="el" href="service_bus_8cpp-example.html#a23">service_bus.cpp</a>, and <a class="el" href="simple_recv_8cpp-example.html#a14">simple_recv.cpp</a>.</dd>
 </dl>
 </div>
 </div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler-members.html
index 9703a0b..bb6db74 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler-members.html
@@ -96,10 +96,11 @@ $(document).ready(function(){initNavTree('classproton_1_1listen__handler.html','
 
 <p>This is the complete list of members for <a class="el" href="classproton_1_1listen__handler.html">listen_handler</a>, including all inherited members.</p>
 <table class="directory">
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">on_accept</a>(listener &amp;)=0</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">pure virtual</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">on_close</a>(listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">inline</span><span class="mlabel">virtual</span></td></tr>
-  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">on_error</a>(listener &amp;, const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">inline</span><span class="mlabel">virtual</span></td></tr>
-  <tr bgcolor="#f0f0f0"><td class="entry"><b>~listen_handler</b>() (defined in <a class="el" href="classproton_1_1listen__handler.html">listen_handler</a>)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">inline</span><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">on_accept</a>(listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">on_close</a>(listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">on_error</a>(listener &amp;, const std::string &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b">on_open</a>(listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
+  <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>~listen_handler</b>() (defined in <a class="el" href="classproton_1_1listen__handler.html">listen_handler</a>)</td><td class="entry"><a class="el" href="classproton_1_1listen__handler.html">listen_handler</a></td><td class="entry"><span class="mlabel">virtual</span></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.html
index ce37de4..3a7140d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('classproton_1_1listen__handler.html','
 <a href="#pub-methods">Public Member Functions</a> &#124;
 <a href="classproton_1_1listen__handler-members.html">List of all members</a>  </div>
   <div class="headertitle">
-<div class="title">listen_handler<span class="mlabels"><span class="mlabel">abstract</span></span></div>  </div>
+<div class="title">listen_handler</div>  </div>
 </div><!--header-->
 <div class="contents">
 
@@ -104,9 +104,13 @@ $(document).ready(function(){initNavTree('classproton_1_1listen__handler.html','
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="pub-methods"></a>
 Public Member Functions</h2></td></tr>
-<tr class="memitem:a0936d46edbbecedf7eed44a19677b39b"><td class="memItemLeft" align="right" valign="top">virtual <a class="el" href="classproton_1_1connection__options.html">connection_options</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">on_accept</a> (<a class="el" href="classproton_1_1listener.html">listener</a> &amp;)=0</td></tr>
-<tr class="memdesc:a0936d46edbbecedf7eed44a19677b39b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Called for each accepted connection.  <a href="#a0936d46edbbecedf7eed44a19677b39b">More...</a><br /></td></tr>
-<tr class="separator:a0936d46edbbecedf7eed44a19677b39b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a74a2a66bb05107bd04fbb15731b0578b"><td class="memItemLeft" align="right" valign="top"><a id="a74a2a66bb05107bd04fbb15731b0578b"></a>
+virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b">on_open</a> (<a class="el" href="classproton_1_1listener.html">listener</a> &amp;)</td></tr>
+<tr class="memdesc:a74a2a66bb05107bd04fbb15731b0578b"><td class="mdescLeft">&#160;</td><td class="mdescRight">Called when the listener is opened successfully. <br /></td></tr>
+<tr class="separator:a74a2a66bb05107bd04fbb15731b0578b"><td class="memSeparator" colspan="2">&#160;</td></tr>
+<tr class="memitem:a3f8b8dc9641dc3a3ed19e2a60ec8eccc"><td class="memItemLeft" align="right" valign="top">virtual <a class="el" href="classproton_1_1connection__options.html">connection_options</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">on_accept</a> (<a class="el" href="classproton_1_1listener.html">listener</a> &amp;)</td></tr>
+<tr class="memdesc:a3f8b8dc9641dc3a3ed19e2a60ec8eccc"><td class="mdescLeft">&#160;</td><td class="mdescRight">Called for each accepted connection.  <a href="#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">More...</a><br /></td></tr>
+<tr class="separator:a3f8b8dc9641dc3a3ed19e2a60ec8eccc"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:a0969610957fd465626cfad89db38ef53"><td class="memItemLeft" align="right" valign="top">virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">on_error</a> (<a class="el" href="classproton_1_1listener.html">listener</a> &amp;, const std::string &amp;)</td></tr>
 <tr class="memdesc:a0969610957fd465626cfad89db38ef53"><td class="mdescLeft">&#160;</td><td class="mdescRight">Called if there is a listening error, with an error message.  <a href="#a0969610957fd465626cfad89db38ef53">More...</a><br /></td></tr>
 <tr class="separator:a0969610957fd465626cfad89db38ef53"><td class="memSeparator" colspan="2">&#160;</td></tr>
@@ -118,10 +122,10 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>
 <div class="textblock"><p><b>Unsettled API</b> - A handler for incoming connections. </p>
 <p>Implement this interface and pass to <a class="el" href="classproton_1_1container.html#a9e138b28e9589583915cf5c5e0e7a524" title="Listen for new connections on listen_url. ">proton::container::listen()</a> to be notified of new connections. </p>
-<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a28">broker.cpp</a>.</dd>
+<dl><dt><b>Examples: </b></dt><dd><a class="el" href="broker_8cpp-example.html#_a34">broker.cpp</a>, <a class="el" href="direct_recv_8cpp-example.html#_a1">direct_recv.cpp</a>, <a class="el" href="direct_send_8cpp-example.html#_a1">direct_send.cpp</a>, and <a class="el" href="server_direct_8cpp-example.html#_a1">server_direct.cpp</a>.</dd>
 </dl></div><h2 class="groupheader">Member Function Documentation</h2>
-<a id="a0936d46edbbecedf7eed44a19677b39b"></a>
-<h2 class="memtitle"><span class="permalink"><a href="#a0936d46edbbecedf7eed44a19677b39b">&#9670;&nbsp;</a></span>on_accept()</h2>
+<a id="a3f8b8dc9641dc3a3ed19e2a60ec8eccc"></a>
+<h2 class="memtitle"><span class="permalink"><a href="#a3f8b8dc9641dc3a3ed19e2a60ec8eccc">&#9670;&nbsp;</a></span>on_accept()</h2>
 
 <div class="memitem">
 <div class="memproto">
@@ -139,13 +143,13 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
       </table>
   </td>
   <td class="mlabels-right">
-<span class="mlabels"><span class="mlabel">pure virtual</span></span>  </td>
+<span class="mlabels"><span class="mlabel">virtual</span></span>  </td>
   </tr>
 </table>
 </div><div class="memdoc">
 
 <p>Called for each accepted connection. </p>
-<p>Returns <a class="el" href="classproton_1_1connection__options.html" title="Options for creating a connection. ">connection_options</a> to apply, including a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a> for the connection. <a class="el" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a> will be called with the <a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a>, it can call <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a> to accept or <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca" title="Close the endpoint. ">connection::close()</a> to reject the connection. </p>
+<p>Returns <a class="el" href="classproton_1_1connection__options.html" title="Options for creating a connection. ">connection_options</a> to apply, including a <a class="el" href="classproton_1_1messaging__handler.html" title="A handler for Proton messaging events. ">proton::messaging_handler</a> for the connection. <a class="el" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768" title="The remote peer opened the connection. ">messaging_handler::on_connection_open()</a> will be called with the <a class="el" href="classproton_1_1connection.html" title="A connection to a remote AMQP peer. ">proton::connection</a>, it can call <a class="el" href="classproton_1_1connection.html#a9e8555112049fc2b4945120b3c45f8ab" title="Open the connection. ">connection::open()</a> to accept or <a class="el" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca" title="Close the endpoint. ">connection::close()</a> to reject the connection. </p>
 
 </div>
 </div>
@@ -178,7 +182,7 @@ virtual void&#160;</td><td class="memItemRight" valign="bottom"><a class="el" hr
       </table>
   </td>
   <td class="mlabels-right">
-<span class="mlabels"><span class="mlabel">inline</span><span class="mlabel">virtual</span></span>  </td>
+<span class="mlabels"><span class="mlabel">virtual</span></span>  </td>
   </tr>
 </table>
 </div><div class="memdoc">

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.js b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.js
index 276f396..f42ae05 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listen__handler.js
@@ -1,7 +1,8 @@
 var classproton_1_1listen__handler =
 [
     [ "~listen_handler", "classproton_1_1listen__handler.html#a75bbe826066a9de53aec34a3e858f24b", null ],
-    [ "on_accept", "classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b", null ],
+    [ "on_open", "classproton_1_1listen__handler.html#a74a2a66bb05107bd04fbb15731b0578b", null ],
+    [ "on_accept", "classproton_1_1listen__handler.html#a3f8b8dc9641dc3a3ed19e2a60ec8eccc", null ],
     [ "on_error", "classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53", null ],
     [ "on_close", "classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener-members.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener-members.html b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener-members.html
index b366115..c457cba 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener-members.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/classproton_1_1listener-members.html
@@ -97,8 +97,13 @@ $(document).ready(function(){initNavTree('classproton_1_1listener.html','');});
 <p>This is the complete list of members for <a class="el" href="classproton_1_1listener.html">listener</a>, including all inherited members.</p>
 <table class="directory">
   <tr bgcolor="#f0f0f0" class="even"><td class="entry"><b>container</b> (defined in <a class="el" href="classproton_1_1listener.html">listener</a>)</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"><span class="mlabel">friend</span></td></tr>
-  <tr><td class="entry"><a class="el" href="classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814">listener</a>()</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1listener.html#a2f632b80247e868b8264b8a025b84baf">container</a>() const</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listener.html#a59dc4506a73a3d4ae084b5fc1d014814">listener</a>()</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1listener.html#a3edec85cbcde06b471e8e2fb4726dbf5">listener</a>(const listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listener.html#a426fa804e3bb58ef90b29b066c3f5199">operator=</a>(const listener &amp;)</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr><td class="entry"><a class="el" href="classproton_1_1listener.html#a0a3b88007d7cb5fa8d890376c5a8b102">port</a>()</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
   <tr class="even"><td class="entry"><a class="el" href="classproton_1_1listener.html#a8c528baf37154d347366083f0f816846">stop</a>()</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
+  <tr bgcolor="#f0f0f0"><td class="entry"><b>~listener</b>() (defined in <a class="el" href="classproton_1_1listener.html">listener</a>)</td><td class="entry"><a class="el" href="classproton_1_1listener.html">listener</a></td><td class="entry"></td></tr>
 </table></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->


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


[03/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/message_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/message_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/message_8hpp_source.html
index f8b6bc1..cd2d394 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/message_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/message_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('message_8hpp_source.html','');});
 <div class="title">message.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="message_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGE_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGE_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license
  agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span c
 lass="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</s
 pan></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line">
 <a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="duration_8hpp.html">./duration.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="timestamp_8hpp.html">./timestamp.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="value_8hpp.html">./value.hpp</a>&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="map_8hpp.html">./map.hpp</a>&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&
 quot;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">struct </span>pn_message_t;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&
 #160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="classproton_1_1message.html">   50</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1message.html">message</a> {</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">   54</a></span>&#160;    <span class="keyword">typedef</span> <a class="code" href="classproton_1_1map.html">map&lt;std::string, scalar&gt;</a> <a class="code" href="classproton_1_1message.html#a071e4357cc12168d97a725
 1b5a5b9784">property_map</a>;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;</div><div class="line"><a name="l00058"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">   58</a></span>&#160;    <span class="keyword">typedef</span> <a class="code" href="classproton_1_1map.html">map&lt;annotation_key, value&gt;</a> <a class="code" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a>;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>();</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;    PN_CPP_EXTERN <a class="c
 ode" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html">message</a>&amp; <a class="code" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">operator=</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_RVALUE_REFERENCES</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;    PN_CPP_EXTERN <a class="code
 " href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;&amp;);</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html">message</a>&amp; <a class="code" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">operator=</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;&amp;);</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<span 
 class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; x);</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;    PN_CPP_EXTERN ~<a class="code" href="classproton_1_1message.html">message</a>();</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;</div><div class="line"><a name="l00087"></a><span class="lineno">   87</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#ac8bb3912a3ce86b15842e79d0b421204">clear</a>();</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href
 ="classproton_1_1message.html#adfd60b48e376c1242e6ee0336804df6e">id</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;</div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message__id.html">message_id</a> <a class="code" href="classproton_1_1message.html#adfd60b48e376c1242e6ee0336804df6e">id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a9444df7d81bd265e0a8e1726fd12b058">user</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00100"></a><span class="
 lineno">  100</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a9444df7d81bd265e0a8e1726fd12b058">user</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#af21dd518ce50ffce76da4cfa7009e56a">encode</a>(std::vector&lt;char&gt;&amp;) <span class="keyword">const</span>;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;</div><div class="line"><a name="l00109"></a><span class="lineno">  109</span>&#160;    PN_CPP_EXTERN std::vector&lt;char&gt; <a class="code" href="classproton_1_1message.html#af21dd518ce50ffce76da4cfa7009e56a">encode</a>() <span class="keyword">const</span
 >;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;</div><div class="line"><a name="l00112"></a><span class="lineno">  112</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a53538e1ae48ba56e7285ca859d9cee50">decode</a>(<span class="keyword">const</span> std::vector&lt;char&gt;&amp;);</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00115"></a><span class="lineno">  115</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;</div><div class="line"><a name="l00120"></a><span class="lineno">  120</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a814dc49160018ce6fc68495b95557917">to</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00121"></a><span class="lineno">  121</
 span>&#160;</div><div class="line"><a name="l00123"></a><span class="lineno">  123</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a814dc49160018ce6fc68495b95557917">to</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00124"></a><span class="lineno">  124</span>&#160;</div><div class="line"><a name="l00127"></a><span class="lineno">  127</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> address(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;    PN_CPP_EXTERN std::string address() <span class="keyword">const</span>;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00132"></a><span class="lineno">  132</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#afaf0d21a2f84f02a3cf12993
 4e2a4245">reply_to</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;</div><div class="line"><a name="l00135"></a><span class="lineno">  135</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#afaf0d21a2f84f02a3cf129934e2a4245">reply_to</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">correlation_id</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00139"></a><span class="lineno">  139</span>&#160;</div><div class="line"><a name="l00141"></a><span class="lineno"
 >  141</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message__id.html">message_id</a> <a class="code" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">correlation_id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00144"></a><span class="lineno">  144</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; x);</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span>&#160;</div><div class="line"><a name="l00152"></a><span class="lineno">  152</span
 >&#160;    PN_CPP_EXTERN <span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;</div><div class="line"><a name="l00155"></a><span class="lineno">  155</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1value.html">value</a>&amp; <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>();</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;</div><div class="line"><a name="l00158"></a><span class="lineno">  158</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a828b19a7f783474c26f7535bbe652c5d">subject</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line
 "><a name="l00159"></a><span class="lineno">  159</span>&#160;</div><div class="line"><a name="l00161"></a><span class="lineno">  161</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a828b19a7f783474c26f7535bbe652c5d">subject</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">content_type</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00167"></a><span class="lineno">  167</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">content_type</a>() <span 
 class="keyword">const</span>;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;</div><div class="line"><a name="l00170"></a><span class="lineno">  170</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">content_encoding</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">content_encoding</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;</div><div class="line"><a name="l00176"></a><span class="lineno">  176</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href
 ="classproton_1_1message.html#a797add180df080ad92c640303b2c5fc8">expiry_time</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;</div><div class="line"><a name="l00179"></a><span class="lineno">  179</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1timestamp.html">timestamp</a> <a class="code" href="classproton_1_1message.html#a797add180df080ad92c640303b2c5fc8">expiry_time</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;</div><div class="line"><a name="l00182"></a><span class="lineno">  182</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">creation_time</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00183"></a><span class="line
 no">  183</span>&#160;</div><div class="line"><a name="l00185"></a><span class="lineno">  185</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1timestamp.html">timestamp</a> <a class="code" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">creation_time</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00186"></a><span class="lineno">  186</span>&#160;</div><div class="line"><a name="l00196"></a><span class="lineno">  196</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a0952cced87e1a210acf6c603eb1b6895">inferred</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a0952cced87e1a210acf6c603eb1b6895
 ">inferred</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00202"></a><span class="lineno">  202</span>&#160;</div><div class="line"><a name="l00205"></a><span class="lineno">  205</span>&#160;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">durable</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00213"></a><span class="lineno">  213</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">durable</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00214"></a><span class=
 "lineno">  214</span>&#160;</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1message.html#a7d214bd08f8c6c4698bb91dedc5aed89">ttl</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00223"></a><span class="lineno">  223</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a7d214bd08f8c6c4698bb91dedc5aed89">ttl</a>(<a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;    PN_CPP_EXTERN uint8_t <a class="code" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">priority</a
 >() <span class="keyword">const</span>;</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">priority</a>(uint8_t);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;    <span class="comment">// XXX The triple-not in the last sentence above is confusing.</span></div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;</div><div class="line"><a name="l00250"></a><span class="lineno">  250</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a6b98f
 907faac42172e8ae1bdaa080e58">first_acquirer</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a6b98f907faac42172e8ae1bdaa080e58">first_acquirer</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;</div><div class="line"><a name="l00259"></a><span class="lineno">  259</span>&#160;    PN_CPP_EXTERN uint32_t <a class="code" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">delivery_count</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;    PN_CPP_EXTERN <span class="keywordtyp
 e">void</span> <a class="code" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">delivery_count</a>(uint32_t);</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;</div><div class="line"><a name="l00265"></a><span class="lineno">  265</span>&#160;</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;</div><div class="line"><a name="l00270"></a><span class="lineno">  270</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a691ee3d0e9c9a156357b63a5661d206a">group_id</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;</div><div class="line"><a name="l00273"></a><span class="lineno">  273</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a691ee3d0e9c9a156357b63a5661d206a">group_id</a>() <span class="keyword">const
 </span>;</div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;</div><div class="line"><a name="l00276"></a><span class="lineno">  276</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a9df0c7820d7beaf3c317c8a0a2545fd1">reply_to_group_id</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;</div><div class="line"><a name="l00279"></a><span class="lineno">  279</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a9df0c7820d7beaf3c317c8a0a2545fd1">reply_to_group_id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00280"></a><span class="lineno">  280</span>&#160;</div><div class="line"><a name="l00286"></a><span class="lineno">  286</span>&#160;    PN_CPP_EXTERN int32_t <a class="code" href="classproton_1_1message.html#afad787e06e9c46c11e
 72b7c117c278e9">group_sequence</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;</div><div class="line"><a name="l00289"></a><span class="lineno">  289</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#afad787e06e9c46c11e72b7c117c278e9">group_sequence</a>(int32_t);</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;</div><div class="line"><a name="l00292"></a><span class="lineno">  292</span>&#160;</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;</div><div class="line"><a name="l00298"></a><span class="lineno">  298</span>&#160;    PN_CPP_EXTERN property_map&amp; <a class="code" href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">properties</a>();</div><div class="line"><a name="l00299"></a><span class="lineno">  299</span>&#160;</div><div class="line"><a nam
 e="l00301"></a><span class="lineno">  301</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> property_map&amp; <a class="code" href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">properties</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00302"></a><span class="lineno">  302</span>&#160;</div><div class="line"><a name="l00307"></a><span class="lineno">  307</span>&#160;    PN_CPP_EXTERN annotation_map&amp; message_annotations();</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> annotation_map&amp; message_annotations() <span class="keyword">const</span>;</div><div class="line"><a name="l00309"></a><span class="lineno">  309</span>&#160;</div><div class="line"><a name="l00310"></a><span class="lineno">  310</span>&#160;    PN_CPP_EXTERN annotation_map&amp; delivery_annotations();</div><div class="line"><a name="l00311"></a><span class="lineno
 ">  311</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> annotation_map&amp; delivery_annotations() <span class="keyword">const</span>;</div><div class="line"><a name="l00313"></a><span class="lineno">  313</span>&#160;</div><div class="line"><a name="l00315"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">  315</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> uint8_t <a class="code" href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">default_priority</a>;</div><div class="line"><a name="l00316"></a><span class="lineno">  316</span>&#160;</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;    <span class="keyword">struct </span>impl;</div><div class="line"><a name="l00320"></a><span
  class="lineno">  320</span>&#160;    pn_message_t* pn_msg() <span class="keyword">const</span>;</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;    <span class="keyword">struct </span>impl&amp; impl() <span class="keyword">const</span>;</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;</div><div class="line"><a name="l00323"></a><span class="lineno">  323</span>&#160;    <span class="keyword">mutable</span> pn_message_t* pn_msg_;</div><div class="line"><a name="l00324"></a><span class="lineno">  324</span>&#160;</div><div class="line"><a name="l00325"></a><span class="lineno">  325</span>&#160;  PN_CPP_EXTERN <span class="keyword">friend</span> <span class="keywordtype">void</span> <a class="code" href="namespaceproton.html#ac316ee696bc5099a42ecec8ed4d8f656">swap</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;, <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div 
 class="line"><a name="l00327"></a><span class="lineno">  327</span>&#160;};</div><div class="line"><a name="l00328"></a><span class="lineno">  328</span>&#160;</div><div class="line"><a name="l00329"></a><span class="lineno">  329</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;</div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;<span class="preprocessor">#endif // PROTON_MESSAGE_HPP</span></div><div class="ttc" id="classproton_1_1message_html"><div class="ttname"><a href="classproton_1_1message.html">proton::message</a></div><div class="ttdoc">An AMQP message. </div><div class="ttdef"><b>Definition:</b> message.hpp:50</div></div>
+<a href="message_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_MESSAGE_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_MESSAGE_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license
  agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span c
 lass="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</s
 pan></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line">
 <a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="duration_8hpp.html">./duration.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="timestamp_8hpp.html">./timestamp.hpp</a>&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="value_8hpp.html">./value.hpp</a>&quot;</span></div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="map_8hpp.html">./map.hpp</a>&quot;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#include &quot;./internal/pn_unique_ptr.hpp&
 quot;</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="preprocessor">#include &lt;vector&gt;</span></div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">struct </span>pn_message_t;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&
 #160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;</div><div class="line"><a name="l00050"></a><span class="lineno"><a class="line" href="classproton_1_1message.html">   50</a></span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1message.html">message</a> {</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00053"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">   53</a></span>&#160;    <span class="keyword">typedef</span> <a class="code" href="classproton_1_1map.html">map&lt;std::string, scalar&gt;</a> <a class="code" href="classproton_1_1message.html#a071e4357cc12168d97a725
 1b5a5b9784">property_map</a>;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">   56</a></span>&#160;    <span class="keyword">typedef</span> <a class="code" href="classproton_1_1map.html">map&lt;annotation_key, value&gt;</a> <a class="code" href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">annotation_map</a>;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>();</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;    PN_CPP_EXTERN <a class="c
 ode" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html">message</a>&amp; <a class="code" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">operator=</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_RVALUE_REFERENCES</span></div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    PN_CPP_EXTERN <a class="code
 " href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;&amp;);</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html">message</a>&amp; <a class="code" href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">operator=</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;&amp;);</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message.html#aba502b8bb024cc38b45756fdf581f915">message</a>(<span 
 class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; x);</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN ~<a class="code" href="classproton_1_1message.html">message</a>();</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#ac8bb3912a3ce86b15842e79d0b421204">clear</a>();</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href
 ="classproton_1_1message.html#adfd60b48e376c1242e6ee0336804df6e">id</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message__id.html">message_id</a> <a class="code" href="classproton_1_1message.html#adfd60b48e376c1242e6ee0336804df6e">id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a9444df7d81bd265e0a8e1726fd12b058">user</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00098"></a><span class="
 lineno">   98</span>&#160;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a9444df7d81bd265e0a8e1726fd12b058">user</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00101"></a><span class="lineno">  101</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#af21dd518ce50ffce76da4cfa7009e56a">encode</a>(std::vector&lt;char&gt;&amp;) <span class="keyword">const</span>;</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00107"></a><span class="lineno">  107</span>&#160;    PN_CPP_EXTERN std::vector&lt;char&gt; <a class="code" href="classproton_1_1message.html#af21dd518ce50ffce76da4cfa7009e56a">encode</a>() <span class="keyword">const</span
 >;</div><div class="line"><a name="l00108"></a><span class="lineno">  108</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a53538e1ae48ba56e7285ca859d9cee50">decode</a>(<span class="keyword">const</span> std::vector&lt;char&gt;&amp;);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div class="line"><a name="l00113"></a><span class="lineno">  113</span>&#160;</div><div class="line"><a name="l00116"></a><span class="lineno">  116</span>&#160;</div><div class="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a814dc49160018ce6fc68495b95557917">to</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</
 span>&#160;</div><div class="line"><a name="l00121"></a><span class="lineno">  121</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a814dc49160018ce6fc68495b95557917">to</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00122"></a><span class="lineno">  122</span>&#160;</div><div class="line"><a name="l00125"></a><span class="lineno">  125</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> address(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00126"></a><span class="lineno">  126</span>&#160;    PN_CPP_EXTERN std::string address() <span class="keyword">const</span>;</div><div class="line"><a name="l00128"></a><span class="lineno">  128</span>&#160;</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#afaf0d21a2f84f02a3cf12993
 4e2a4245">reply_to</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00131"></a><span class="lineno">  131</span>&#160;</div><div class="line"><a name="l00133"></a><span class="lineno">  133</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#afaf0d21a2f84f02a3cf129934e2a4245">reply_to</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00134"></a><span class="lineno">  134</span>&#160;</div><div class="line"><a name="l00136"></a><span class="lineno">  136</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">correlation_id</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1message__id.html">message_id</a>&amp;);</div><div class="line"><a name="l00137"></a><span class="lineno">  137</span>&#160;</div><div class="line"><a name="l00139"></a><span class="lineno"
 >  139</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1message__id.html">message_id</a> <a class="code" href="classproton_1_1message.html#af315e837ef0814fac5c50cb9e1ef3c3a">correlation_id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00140"></a><span class="lineno">  140</span>&#160;</div><div class="line"><a name="l00142"></a><span class="lineno">  142</span>&#160;</div><div class="line"><a name="l00145"></a><span class="lineno">  145</span>&#160;</div><div class="line"><a name="l00147"></a><span class="lineno">  147</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>(<span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; x);</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;</div><div class="line"><a name="l00150"></a><span class="lineno">  150</span
 >&#160;    PN_CPP_EXTERN <span class="keyword">const</span> <a class="code" href="classproton_1_1value.html">value</a>&amp; <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00151"></a><span class="lineno">  151</span>&#160;</div><div class="line"><a name="l00153"></a><span class="lineno">  153</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1value.html">value</a>&amp; <a class="code" href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">body</a>();</div><div class="line"><a name="l00154"></a><span class="lineno">  154</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a828b19a7f783474c26f7535bbe652c5d">subject</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line
 "><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00159"></a><span class="lineno">  159</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a828b19a7f783474c26f7535bbe652c5d">subject</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00160"></a><span class="lineno">  160</span>&#160;</div><div class="line"><a name="l00162"></a><span class="lineno">  162</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">content_type</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00163"></a><span class="lineno">  163</span>&#160;</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">content_type</a>() <span 
 class="keyword">const</span>;</div><div class="line"><a name="l00166"></a><span class="lineno">  166</span>&#160;</div><div class="line"><a name="l00168"></a><span class="lineno">  168</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">content_encoding</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00169"></a><span class="lineno">  169</span>&#160;</div><div class="line"><a name="l00171"></a><span class="lineno">  171</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">content_encoding</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;</div><div class="line"><a name="l00174"></a><span class="lineno">  174</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href
 ="classproton_1_1message.html#a797add180df080ad92c640303b2c5fc8">expiry_time</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00175"></a><span class="lineno">  175</span>&#160;</div><div class="line"><a name="l00177"></a><span class="lineno">  177</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1timestamp.html">timestamp</a> <a class="code" href="classproton_1_1message.html#a797add180df080ad92c640303b2c5fc8">expiry_time</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00178"></a><span class="lineno">  178</span>&#160;</div><div class="line"><a name="l00180"></a><span class="lineno">  180</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">creation_time</a>(<a class="code" href="classproton_1_1timestamp.html">timestamp</a>);</div><div class="line"><a name="l00181"></a><span class="line
 no">  181</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1timestamp.html">timestamp</a> <a class="code" href="classproton_1_1message.html#a178b791501dfdb0b0b01922d6a3ddcb1">creation_time</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00194"></a><span class="lineno">  194</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a0952cced87e1a210acf6c603eb1b6895">inferred</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00195"></a><span class="lineno">  195</span>&#160;</div><div class="line"><a name="l00197"></a><span class="lineno">  197</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a0952cced87e1a210acf6c603eb1b6895
 ">inferred</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00198"></a><span class="lineno">  198</span>&#160;</div><div class="line"><a name="l00200"></a><span class="lineno">  200</span>&#160;</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;</div><div class="line"><a name="l00208"></a><span class="lineno">  208</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">durable</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00209"></a><span class="lineno">  209</span>&#160;</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">durable</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00212"></a><span class=
 "lineno">  212</span>&#160;</div><div class="line"><a name="l00220"></a><span class="lineno">  220</span>&#160;    PN_CPP_EXTERN <a class="code" href="classproton_1_1duration.html">duration</a> <a class="code" href="classproton_1_1message.html#a7d214bd08f8c6c4698bb91dedc5aed89">ttl</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;</div><div class="line"><a name="l00223"></a><span class="lineno">  223</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a7d214bd08f8c6c4698bb91dedc5aed89">ttl</a>(<a class="code" href="classproton_1_1duration.html">duration</a>);</div><div class="line"><a name="l00224"></a><span class="lineno">  224</span>&#160;</div><div class="line"><a name="l00232"></a><span class="lineno">  232</span>&#160;    PN_CPP_EXTERN uint8_t <a class="code" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">priority</a
 >() <span class="keyword">const</span>;</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;</div><div class="line"><a name="l00235"></a><span class="lineno">  235</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#ab558bc7b971e0c09d6ca1f4f93d71b41">priority</a>(uint8_t);</div><div class="line"><a name="l00236"></a><span class="lineno">  236</span>&#160;</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;</div><div class="line"><a name="l00246"></a><span class="lineno">  246</span>&#160;    <span class="comment">// XXX The triple-not in the last sentence above is confusing.</span></div><div class="line"><a name="l00247"></a><span class="lineno">  247</span>&#160;</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> <a class="code" href="classproton_1_1message.html#a6b98f
 907faac42172e8ae1bdaa080e58">first_acquirer</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;</div><div class="line"><a name="l00251"></a><span class="lineno">  251</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a6b98f907faac42172e8ae1bdaa080e58">first_acquirer</a>(<span class="keywordtype">bool</span>);</div><div class="line"><a name="l00252"></a><span class="lineno">  252</span>&#160;</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;    PN_CPP_EXTERN uint32_t <a class="code" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">delivery_count</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00258"></a><span class="lineno">  258</span>&#160;</div><div class="line"><a name="l00260"></a><span class="lineno">  260</span>&#160;    PN_CPP_EXTERN <span class="keywordtyp
 e">void</span> <a class="code" href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">delivery_count</a>(uint32_t);</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;</div><div class="line"><a name="l00263"></a><span class="lineno">  263</span>&#160;</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;</div><div class="line"><a name="l00268"></a><span class="lineno">  268</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a691ee3d0e9c9a156357b63a5661d206a">group_id</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00269"></a><span class="lineno">  269</span>&#160;</div><div class="line"><a name="l00271"></a><span class="lineno">  271</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a691ee3d0e9c9a156357b63a5661d206a">group_id</a>() <span class="keyword">const
 </span>;</div><div class="line"><a name="l00272"></a><span class="lineno">  272</span>&#160;</div><div class="line"><a name="l00274"></a><span class="lineno">  274</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#a9df0c7820d7beaf3c317c8a0a2545fd1">reply_to_group_id</a>(<span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;</div><div class="line"><a name="l00277"></a><span class="lineno">  277</span>&#160;    PN_CPP_EXTERN std::string <a class="code" href="classproton_1_1message.html#a9df0c7820d7beaf3c317c8a0a2545fd1">reply_to_group_id</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00278"></a><span class="lineno">  278</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;    PN_CPP_EXTERN int32_t <a class="code" href="classproton_1_1message.html#afad787e06e9c46c11e
 72b7c117c278e9">group_sequence</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> <a class="code" href="classproton_1_1message.html#afad787e06e9c46c11e72b7c117c278e9">group_sequence</a>(int32_t);</div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;</div><div class="line"><a name="l00290"></a><span class="lineno">  290</span>&#160;</div><div class="line"><a name="l00293"></a><span class="lineno">  293</span>&#160;</div><div class="line"><a name="l00296"></a><span class="lineno">  296</span>&#160;    PN_CPP_EXTERN property_map&amp; <a class="code" href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">properties</a>();</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;</div><div class="line"><a nam
 e="l00299"></a><span class="lineno">  299</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> property_map&amp; <a class="code" href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">properties</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00300"></a><span class="lineno">  300</span>&#160;</div><div class="line"><a name="l00303"></a><span class="lineno">  303</span>&#160;    PN_CPP_EXTERN annotation_map&amp; <a class="code" href="classproton_1_1message.html#a5d96699458d8be84d821f5651a7b3717">message_annotations</a>();</div><div class="line"><a name="l00304"></a><span class="lineno">  304</span>&#160;</div><div class="line"><a name="l00306"></a><span class="lineno">  306</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> annotation_map&amp; <a class="code" href="classproton_1_1message.html#a5d96699458d8be84d821f5651a7b3717">message_annotations</a>() <span class="keyword">const</span>;</div><div class="line"><a name
 ="l00307"></a><span class="lineno">  307</span>&#160;</div><div class="line"><a name="l00310"></a><span class="lineno">  310</span>&#160;    PN_CPP_EXTERN annotation_map&amp; <a class="code" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">delivery_annotations</a>();</div><div class="line"><a name="l00311"></a><span class="lineno">  311</span>&#160;</div><div class="line"><a name="l00313"></a><span class="lineno">  313</span>&#160;    PN_CPP_EXTERN <span class="keyword">const</span> annotation_map&amp; <a class="code" href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">delivery_annotations</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00314"></a><span class="lineno">  314</span>&#160;</div><div class="line"><a name="l00316"></a><span class="lineno">  316</span>&#160;</div><div class="line"><a name="l00318"></a><span class="lineno"><a class="line" href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">  3
 18</a></span>&#160;    PN_CPP_EXTERN <span class="keyword">static</span> <span class="keyword">const</span> uint8_t <a class="code" href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">default_priority</a>;</div><div class="line"><a name="l00319"></a><span class="lineno">  319</span>&#160;</div><div class="line"><a name="l00321"></a><span class="lineno">  321</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00322"></a><span class="lineno">  322</span>&#160;    <span class="keyword">struct </span>impl;</div><div class="line"><a name="l00323"></a><span class="lineno">  323</span>&#160;    pn_message_t* pn_msg() <span class="keyword">const</span>;</div><div class="line"><a name="l00324"></a><span class="lineno">  324</span>&#160;    <span class="keyword">struct </span>impl&amp; impl() <span class="keyword">const</span>;</div><div class="line"><a name="l00325"></a><span class="lineno">  325</span>&#160;</div><div class="line"><a name="
 l00326"></a><span class="lineno">  326</span>&#160;    <span class="keyword">mutable</span> pn_message_t* pn_msg_;</div><div class="line"><a name="l00327"></a><span class="lineno">  327</span>&#160;</div><div class="line"><a name="l00328"></a><span class="lineno">  328</span>&#160;  PN_CPP_EXTERN <span class="keyword">friend</span> <span class="keywordtype">void</span> <a class="code" href="namespaceproton.html#ac316ee696bc5099a42ecec8ed4d8f656">swap</a>(<a class="code" href="classproton_1_1message.html">message</a>&amp;, <a class="code" href="classproton_1_1message.html">message</a>&amp;);</div><div class="line"><a name="l00330"></a><span class="lineno">  330</span>&#160;};</div><div class="line"><a name="l00331"></a><span class="lineno">  331</span>&#160;</div><div class="line"><a name="l00332"></a><span class="lineno">  332</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00333"></a><span class="lineno">  333</span>&#160;</div><div class="line
 "><a name="l00334"></a><span class="lineno">  334</span>&#160;<span class="preprocessor">#endif // PROTON_MESSAGE_HPP</span></div><div class="ttc" id="classproton_1_1message_html"><div class="ttname"><a href="classproton_1_1message.html">proton::message</a></div><div class="ttdoc">An AMQP message. </div><div class="ttdef"><b>Definition:</b> message.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1message_html_a691ee3d0e9c9a156357b63a5661d206a"><div class="ttname"><a href="classproton_1_1message.html#a691ee3d0e9c9a156357b63a5661d206a">proton::message::group_id</a></div><div class="ttdeci">std::string group_id() const</div><div class="ttdoc">Get the message group ID. </div></div>
 <div class="ttc" id="classproton_1_1message_html_a96b6a6416cd89708ff96558bba498305"><div class="ttname"><a href="classproton_1_1message.html#a96b6a6416cd89708ff96558bba498305">proton::message::body</a></div><div class="ttdeci">const value &amp; body() const</div><div class="ttdoc">Get the body. </div></div>
 <div class="ttc" id="classproton_1_1message_html_a0952cced87e1a210acf6c603eb1b6895"><div class="ttname"><a href="classproton_1_1message.html#a0952cced87e1a210acf6c603eb1b6895">proton::message::inferred</a></div><div class="ttdeci">bool inferred() const</div><div class="ttdoc">Get the inferred flag. </div></div>
@@ -108,13 +108,15 @@ $(document).ready(function(){initNavTree('message_8hpp_source.html','');});
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1message_html_ab8eed6909bec0a2ca6a76abed732a7e2"><div class="ttname"><a href="classproton_1_1message.html#ab8eed6909bec0a2ca6a76abed732a7e2">proton::message::delivery_count</a></div><div class="ttdeci">uint32_t delivery_count() const</div><div class="ttdoc">Get the delivery count. </div></div>
 <div class="ttc" id="map_8hpp_html"><div class="ttname"><a href="map_8hpp.html">map.hpp</a></div><div class="ttdoc">A collection of key-value pairs. </div></div>
-<div class="ttc" id="classproton_1_1message_html_a071e4357cc12168d97a7251b5a5b9784"><div class="ttname"><a href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">proton::message::property_map</a></div><div class="ttdeci">map&lt; std::string, scalar &gt; property_map</div><div class="ttdoc">Unsettled API - A map of string keys and AMQP scalar values. </div><div class="ttdef"><b>Definition:</b> message.hpp:54</div></div>
+<div class="ttc" id="classproton_1_1message_html_a071e4357cc12168d97a7251b5a5b9784"><div class="ttname"><a href="classproton_1_1message.html#a071e4357cc12168d97a7251b5a5b9784">proton::message::property_map</a></div><div class="ttdeci">map&lt; std::string, scalar &gt; property_map</div><div class="ttdoc">A map of string keys and AMQP scalar values. </div><div class="ttdef"><b>Definition:</b> message.hpp:53</div></div>
 <div class="ttc" id="classproton_1_1map_html"><div class="ttname"><a href="classproton_1_1map.html">proton::map</a></div><div class="ttdoc">A collection of key-value pairs. </div><div class="ttdef"><b>Definition:</b> map.hpp:44</div></div>
 <div class="ttc" id="classproton_1_1message_html_a95e69c65a7be45de4459481aabf3282c"><div class="ttname"><a href="classproton_1_1message.html#a95e69c65a7be45de4459481aabf3282c">proton::message::content_type</a></div><div class="ttdeci">std::string content_type() const</div><div class="ttdoc">Get the content type of the body. </div></div>
+<div class="ttc" id="classproton_1_1message_html_a5d96699458d8be84d821f5651a7b3717"><div class="ttname"><a href="classproton_1_1message.html#a5d96699458d8be84d821f5651a7b3717">proton::message::message_annotations</a></div><div class="ttdeci">annotation_map &amp; message_annotations()</div><div class="ttdoc">Get the message annotations map. </div></div>
+<div class="ttc" id="classproton_1_1message_html_adb613430bba5478feb0c458d8a9e7145"><div class="ttname"><a href="classproton_1_1message.html#adb613430bba5478feb0c458d8a9e7145">proton::message::delivery_annotations</a></div><div class="ttdeci">annotation_map &amp; delivery_annotations()</div><div class="ttdoc">Get the delivery annotations map. </div></div>
 <div class="ttc" id="classproton_1_1message_html_a9444df7d81bd265e0a8e1726fd12b058"><div class="ttname"><a href="classproton_1_1message.html#a9444df7d81bd265e0a8e1726fd12b058">proton::message::user</a></div><div class="ttdeci">std::string user() const</div><div class="ttdoc">Get the user name or ID. </div></div>
 <div class="ttc" id="classproton_1_1message_html_afad787e06e9c46c11e72b7c117c278e9"><div class="ttname"><a href="classproton_1_1message.html#afad787e06e9c46c11e72b7c117c278e9">proton::message::group_sequence</a></div><div class="ttdeci">int32_t group_sequence() const</div><div class="ttdoc">Get the group sequence. </div></div>
 <div class="ttc" id="duration_8hpp_html"><div class="ttname"><a href="duration_8hpp.html">duration.hpp</a></div><div class="ttdoc">A span of time in milliseconds. </div></div>
-<div class="ttc" id="classproton_1_1message_html_a3c6892bfc5d3b4b1972dc23c004929b7"><div class="ttname"><a href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">proton::message::annotation_map</a></div><div class="ttdeci">map&lt; annotation_key, value &gt; annotation_map</div><div class="ttdoc">Unsettled API - A map of AMQP annotation keys and AMQP values. </div><div class="ttdef"><b>Definition:</b> message.hpp:58</div></div>
+<div class="ttc" id="classproton_1_1message_html_a3c6892bfc5d3b4b1972dc23c004929b7"><div class="ttname"><a href="classproton_1_1message.html#a3c6892bfc5d3b4b1972dc23c004929b7">proton::message::annotation_map</a></div><div class="ttdeci">map&lt; annotation_key, value &gt; annotation_map</div><div class="ttdoc">A map of AMQP annotation keys and AMQP values. </div><div class="ttdef"><b>Definition:</b> message.hpp:56</div></div>
 <div class="ttc" id="classproton_1_1message_html_a828b19a7f783474c26f7535bbe652c5d"><div class="ttname"><a href="classproton_1_1message.html#a828b19a7f783474c26f7535bbe652c5d">proton::message::subject</a></div><div class="ttdeci">std::string subject() const</div><div class="ttdoc">Get the subject. </div></div>
 <div class="ttc" id="classproton_1_1message_html_a55c609ea272a8ec55ce723b6bd0325ea"><div class="ttname"><a href="classproton_1_1message.html#a55c609ea272a8ec55ce723b6bd0325ea">proton::message::durable</a></div><div class="ttdeci">bool durable() const</div><div class="ttdoc">Get the durable flag. </div></div>
 <div class="ttc" id="classproton_1_1timestamp_html"><div class="ttname"><a href="classproton_1_1timestamp.html">proton::timestamp</a></div><div class="ttdoc">A 64-bit timestamp in milliseconds since the Unix epoch. </div><div class="ttdef"><b>Definition:</b> timestamp.hpp:35</div></div>
@@ -122,10 +124,10 @@ $(document).ready(function(){initNavTree('message_8hpp_source.html','');});
 <div class="ttc" id="classproton_1_1message_html_a814dc49160018ce6fc68495b95557917"><div class="ttname"><a href="classproton_1_1message.html#a814dc49160018ce6fc68495b95557917">proton::message::to</a></div><div class="ttdeci">std::string to() const</div><div class="ttdoc">Get the destination address. </div></div>
 <div class="ttc" id="classproton_1_1message_html_af7deffda335cb4457af3830b798182f4"><div class="ttname"><a href="classproton_1_1message.html#af7deffda335cb4457af3830b798182f4">proton::message::operator=</a></div><div class="ttdeci">message &amp; operator=(const message &amp;)</div><div class="ttdoc">Copy a message. </div></div>
 <div class="ttc" id="classproton_1_1message_html_ac8bb3912a3ce86b15842e79d0b421204"><div class="ttname"><a href="classproton_1_1message.html#ac8bb3912a3ce86b15842e79d0b421204">proton::message::clear</a></div><div class="ttdeci">void clear()</div><div class="ttdoc">Clear the message content and properties. </div></div>
-<div class="ttc" id="classproton_1_1message_html_a2014354e2553f4acc49fc9a921da7e92"><div class="ttname"><a href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">proton::message::default_priority</a></div><div class="ttdeci">static const uint8_t default_priority</div><div class="ttdoc">Default priority assigned to new messages. </div><div class="ttdef"><b>Definition:</b> message.hpp:315</div></div>
+<div class="ttc" id="classproton_1_1message_html_a2014354e2553f4acc49fc9a921da7e92"><div class="ttname"><a href="classproton_1_1message.html#a2014354e2553f4acc49fc9a921da7e92">proton::message::default_priority</a></div><div class="ttdeci">static const uint8_t default_priority</div><div class="ttdoc">Default priority assigned to new messages. </div><div class="ttdef"><b>Definition:</b> message.hpp:318</div></div>
 <div class="ttc" id="classproton_1_1message_html_a797add180df080ad92c640303b2c5fc8"><div class="ttname"><a href="classproton_1_1message.html#a797add180df080ad92c640303b2c5fc8">proton::message::expiry_time</a></div><div class="ttdeci">timestamp expiry_time() const</div><div class="ttdoc">Get the expiration time. </div></div>
 <div class="ttc" id="classproton_1_1message_html_aae09423b599b0711618dba1fea27e5c5"><div class="ttname"><a href="classproton_1_1message.html#aae09423b599b0711618dba1fea27e5c5">proton::message::content_encoding</a></div><div class="ttdeci">std::string content_encoding() const</div><div class="ttdoc">Get the content encoding of the body. </div></div>
-<div class="ttc" id="classproton_1_1message_html_ac163919aa25a6ed5b33a29a96d04e028"><div class="ttname"><a href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">proton::message::properties</a></div><div class="ttdeci">property_map &amp; properties()</div><div class="ttdoc">Unsettled API - Get the application properties map. </div></div>
+<div class="ttc" id="classproton_1_1message_html_ac163919aa25a6ed5b33a29a96d04e028"><div class="ttname"><a href="classproton_1_1message.html#ac163919aa25a6ed5b33a29a96d04e028">proton::message::properties</a></div><div class="ttdeci">property_map &amp; properties()</div><div class="ttdoc">Get the application properties map. </div></div>
 <div class="ttc" id="classproton_1_1message_html_a9df0c7820d7beaf3c317c8a0a2545fd1"><div class="ttname"><a href="classproton_1_1message.html#a9df0c7820d7beaf3c317c8a0a2545fd1">proton::message::reply_to_group_id</a></div><div class="ttdeci">std::string reply_to_group_id() const</div><div class="ttdoc">Get the reply-to group ID. </div></div>
 <div class="ttc" id="classproton_1_1message_html_afaf0d21a2f84f02a3cf129934e2a4245"><div class="ttname"><a href="classproton_1_1message.html#afaf0d21a2f84f02a3cf129934e2a4245">proton::message::reply_to</a></div><div class="ttdeci">std::string reply_to() const</div><div class="ttdoc">Get the address for replies. </div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>


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


[37/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/messenger_8h.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/messenger_8h.html b/content/releases/qpid-proton-master/proton/c/api/messenger_8h.html
index 0825a66..3fb0fc1 100755
--- a/content/releases/qpid-proton-master/proton/c/api/messenger_8h.html
+++ b/content/releases/qpid-proton-master/proton/c/api/messenger_8h.html
@@ -130,8 +130,9 @@ Typedefs</h2></td></tr>
 <tr class="memitem:ga0d342bb795d48591ad6b3f867766b8b1"><td class="memItemLeft" align="right" valign="top">typedef struct <a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a></td></tr>
 <tr class="memdesc:ga0d342bb795d48591ad6b3f867766b8b1"><td class="mdescLeft">&#160;</td><td class="mdescRight">A <a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1" title="A pn_messenger_t provides a high level interface for sending and receiving messages (See pn_message_t...">pn_messenger_t</a> provides a high level interface for sending and receiving messages (See <a class="el" href="group__message.html#gad9259fa9271e8844c8e05a7e8978e3b2" title="An AMQP Message object. ">pn_message_t</a>).  <a href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">More...</a><br /></td></tr>
 <tr class="separator:ga0d342bb795d48591ad6b3f867766b8b1"><td class="memSeparator" colspan="2">&#160;</td></tr>
-<tr class="memitem:gabd73703511b9dae193765e9e57864291"><td class="memItemLeft" align="right" valign="top">typedef struct <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a></td></tr>
-<tr class="memdesc:gabd73703511b9dae193765e9e57864291"><td class="mdescLeft">&#160;</td><td class="mdescRight">A subscription is a request for incoming messages.  <a href="group__messenger.html#gabd73703511b9dae193765e9e57864291">More...</a><br /></td></tr>
+<tr class="memitem:gabd73703511b9dae193765e9e57864291"><td class="memItemLeft" align="right" valign="top">
+typedef struct <a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a>&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gabd73703511b9dae193765e9e57864291">pn_subscription_t</a></td></tr>
+<tr class="memdesc:gabd73703511b9dae193765e9e57864291"><td class="mdescLeft">&#160;</td><td class="mdescRight">A subscription is a request for incoming messages. <br /></td></tr>
 <tr class="separator:gabd73703511b9dae193765e9e57864291"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:gab1173cfe4bcaa0a530c8035dc75f42c7"><td class="memItemLeft" align="right" valign="top">
 typedef int64_t&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#gab1173cfe4bcaa0a530c8035dc75f42c7">pn_tracker_t</a></td></tr>
@@ -341,7 +342,7 @@ Functions</h2></td></tr>
 <tr class="memdesc:ga9be25d57cda5a6e1c5658b0f362c41c7"><td class="mdescLeft">&#160;</td><td class="mdescRight">Gets the remote idle timeout for the specified remote service address.  <a href="group__messenger.html#ga9be25d57cda5a6e1c5658b0f362c41c7">More...</a><br /></td></tr>
 <tr class="separator:ga9be25d57cda5a6e1c5658b0f362c41c7"><td class="memSeparator" colspan="2">&#160;</td></tr>
 <tr class="memitem:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="memItemLeft" align="right" valign="top">int&#160;</td><td class="memItemRight" valign="bottom"><a class="el" href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">pn_messenger_set_ssl_peer_authentication_mode</a> (<a class="el" href="group__messenger.html#ga0d342bb795d48591ad6b3f867766b8b1">pn_messenger_t</a> *messenger, const <a class="el" href="group__ssl.html#gae5e33024ed6af3432d4c76d1484d7ecb">pn_ssl_verify_mode_t</a> mode)</td></tr>
-<tr class="memdesc:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Sets the SSL peer authentiacation mode required when a trust certificate is used.  <a href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">More...</a><br /></td></tr>
+<tr class="memdesc:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="mdescLeft">&#160;</td><td class="mdescRight">Sets the SSL peer authentication mode required when a trust certificate is used.  <a href="group__messenger.html#ga59ebaf21eaafaa4b1c359e4284564ff6">More...</a><br /></td></tr>
 <tr class="separator:ga59ebaf21eaafaa4b1c359e4284564ff6"><td class="memSeparator" colspan="2">&#160;</td></tr>
 </table>
 <a name="details" id="details"></a><h2 class="groupheader">Detailed Description</h2>


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


[05/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/functions_w.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/functions_w.html b/content/releases/qpid-proton-master/proton/cpp/api/functions_w.html
index b2930c2..9966829 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/functions_w.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/functions_w.html
@@ -98,15 +98,12 @@ $(document).ready(function(){initNavTree('functions_w.html','');});
 <li>what()
 : <a class="el" href="classproton_1_1error__condition.html#ad2e53bd52dbb1d59081ee7f9f1efc2ac">error_condition</a>
 </li>
-<li>work()
-: <a class="el" href="classproton_1_1work.html#a9d5564deaef15633884ee408f0e92f3a">work</a>
-</li>
 <li>work_queue()
 : <a class="el" href="classproton_1_1connection.html#a7c755d6ac6385e007adb61966598ba63">connection</a>
 , <a class="el" href="classproton_1_1link.html#a7c755d6ac6385e007adb61966598ba63">link</a>
 , <a class="el" href="classproton_1_1session.html#a7c755d6ac6385e007adb61966598ba63">session</a>
 , <a class="el" href="classproton_1_1transfer.html#a7c755d6ac6385e007adb61966598ba63">transfer</a>
-, <a class="el" href="classproton_1_1work__queue.html#a1e7fdf3236c9477c0462214080c34689">work_queue</a>
+, <a class="el" href="classproton_1_1work__queue.html#a689e0d941a552db276229a9fc312e143">work_queue</a>
 </li>
 <li>write_buffer()
 : <a class="el" href="classproton_1_1io_1_1connection__driver.html#aca2fdb0871921fc22ba7c119f8c624f5">connection_driver</a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp.html b/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp.html
index d2578a3..4dee787 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp.html
@@ -99,7 +99,8 @@ $(document).ready(function(){initNavTree('fwd_8hpp.html','');});
 
 <p>Forward declarations.  
 <a href="#details">More...</a></p>
-
+<div class="textblock"><code>#include &quot;./internal/config.hpp&quot;</code><br />
+</div>
 <p><a href="fwd_8hpp_source.html">Go to the source code of this file.</a></p>
 <table class="memberdecls">
 <tr class="heading"><td colspan="2"><h2 class="groupheader"><a name="nested-classes"></a>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp_source.html
index 2afa078..b66d81d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/fwd_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('fwd_8hpp_source.html','');});
 <div class="title">fwd.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="fwd_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_FWD_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_FWD_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.
   See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="commen
 t"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><d
 iv class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l0003
 0"></a><span class="lineno">   30</span>&#160;<span class="keyword">class </span>annotation_key;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">class </span>connection;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="keyword">class </span>connection_options;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">class </span>container;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">class </span>delivery;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">class </span>duration;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="keyword">class </span>error_condition;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="keyword">class <
 /span>event;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">class </span>message;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>message_id;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">class </span>messaging_handler;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">class </span>listen_handler;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">class </span>listener;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">class </span>receiver;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">class </span>receiver_iterator;</div><div class="line"><a name="l00045"></a><span class="lineno
 ">   45</span>&#160;<span class="keyword">class </span>receiver_options;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="keyword">class </span>reconnect_options;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="keyword">class </span>sasl;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">class </span>sender;</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="keyword">class </span>sender_iterator;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="keyword">class </span>sender_options;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="keyword">class </span>session;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="keyword">class </span>session_options;</div><
 div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="keyword">class </span>source_options;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="keyword">class </span>ssl;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="keyword">class </span>target_options;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="keyword">class </span>tracker;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="keyword">class </span>transport;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="keyword">class </span>url;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="keyword">class </span>void_function0;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="key
 word">class </span>work;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="keyword">class </span>work_queue;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;</div><div class="line"><a name="l00063"></a><span class="lineno"><a class="line" href="namespaceproton_1_1io.html">   63</a></span>&#160;<span class="keyword">namespace </span>io {</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1io_1_1connection__driver.html">connection_driver</a>;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;}</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;</div><div class="line"><a name=
 "l00069"></a><span class="lineno"><a class="line" href="classproton_1_1returned.html">   69</a></span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">class </span><a class="code" href="classproton_1_1returned.html">returned</a>;</div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;}</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;<span class="preprocessor">#endif // PROTON_FWD_HPP</span></div><div class="ttc" id="classproton_1_1returned_html"><div class="ttname"><a href="classproton_1_1returned.html">proton::returned</a></div><div class="ttdoc">A return type for container methods. </div><div class="ttdef"><b>Definition:</b> fwd.hpp:69</div></div>
+<a href="fwd_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_FWD_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_FWD_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreements.
   See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="commen
 t"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><d
 iv class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/config.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class=
 "lineno">   30</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="keyword">class </span>annotation_key;</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;<span class="keyword">class </span>connection;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="keyword">class </span>connection_options;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">class </span>container;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;<span class="keyword">class </span>delivery;</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;<span class="keyword">class </span>duration;</di
 v><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;<span class="keyword">class </span>error_condition;</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;<span class="keyword">class </span>event;</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;<span class="keyword">class </span>message;</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;<span class="keyword">class </span>message_id;</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;<span class="keyword">class </span>messaging_handler;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;<span class="keyword">class </span>listen_handler;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;<span class="keyword">class </span>listener;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;<
 span class="keyword">class </span>receiver;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;<span class="keyword">class </span>receiver_iterator;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;<span class="keyword">class </span>receiver_options;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;<span class="keyword">class </span>reconnect_options;</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;<span class="keyword">class </span>sasl;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;<span class="keyword">class </span>sender;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;<span class="keyword">class </span>sender_iterator;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;<span class="keyword">class </span>sender_options;</div><div class="line"><
 a name="l00053"></a><span class="lineno">   53</span>&#160;<span class="keyword">class </span>session;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="keyword">class </span>session_options;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;<span class="keyword">class </span>source_options;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;<span class="keyword">class </span>ssl;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;<span class="keyword">class </span>target_options;</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;<span class="keyword">class </span>tracker;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="keyword">class </span>transport;</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;<span class="keyword">class <
 /span>url;</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;<span class="keyword">class </span>void_function0;</div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;<span class="keyword">class </span>work_queue;</div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="keyword">namespace </span>internal { <span class="keyword">namespace </span>v03 { <span class="keyword">class </span>work; } }</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;<span class="preprocessor">#if PN_CPP_HAS_LAMBDAS &amp;&amp; PN_CPP_HAS_VARIADIC_TEMPLATES</span></div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;<span class="keyword">namespace </span>internal { <span class="keyw
 ord">namespace </span>v11 { <span class="keyword">class </span>work; } }</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;<span class="keyword">using</span> internal::v11::work;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;<span class="preprocessor">#else</span></div><div class="line"><a name="l00070"></a><span class="lineno">   70</span>&#160;<span class="keyword">using</span> internal::v03::work;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno"><a class="line" href="namespaceproton_1_1io.html">   73</a></span>&#160;<span class="keyword">namespace </span>io {</div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00075"></a><span 
 class="lineno">   75</span>&#160;<span class="keyword">class </span><a class="code" href="classproton_1_1io_1_1connection__driver.html">connection_driver</a>;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;}</div><div class="line"><a name="l00078"></a><span class="lineno">   78</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno"><a class="line" href="classproton_1_1returned.html">   79</a></span>&#160;<span class="keyword">template</span> &lt;<span class="keyword">class</span> T&gt; <span class="keyword">class </span><a class="code" href="classproton_1_1returned.html">returned</a>;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;}</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;<span clas
 s="preprocessor">#endif // PROTON_FWD_HPP</span></div><div class="ttc" id="classproton_1_1returned_html"><div class="ttname"><a href="classproton_1_1returned.html">proton::returned</a></div><div class="ttdoc">A return type for container methods. </div><div class="ttdef"><b>Definition:</b> fwd.hpp:79</div></div>
 <div class="ttc" id="classproton_1_1io_1_1connection__driver_html"><div class="ttname"><a href="classproton_1_1io_1_1connection__driver.html">proton::io::connection_driver</a></div><div class="ttdoc">Unsettled API - An AMQP driver for a single connection. </div><div class="ttdef"><b>Definition:</b> connection_driver.hpp:93</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 </div><!-- fragment --></div><!-- contents -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/helloworld_8cpp-example.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/helloworld_8cpp-example.html b/content/releases/qpid-proton-master/proton/cpp/api/helloworld_8cpp-example.html
index c0be75d..6453864 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/helloworld_8cpp-example.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/helloworld_8cpp-example.html
@@ -94,7 +94,7 @@ $(document).ready(function(){initNavTree('helloworld_8cpp-example.html','');});
 </div><!--header-->
 <div class="contents">
 <p>Connects to a broker on 127.0.0.1:5672, establishes a subscription from the 'examples' node, and creates a sending link to the same node. Sends one message and receives it back.</p>
-<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="url_8hpp.html">proton/url.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &l
 t;iostream&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>hello_world : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">  <span class="keyword">private</span>:</div><div class="line">    <a name="_a1"></a><a class="code" href="classproton_1_1url.html">proton::url</a> url;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    hello_world(<span class="keyword">const</span> std::string&amp; u) : url(u) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a2"></a><a class="code" href="classproton_1_1messaging__handler.html#a4949b0c93402fae0c07492d984688a25">on_container_start</a>(<a name="_a3"></a><a 
 class="code" href="classproton_1_1container.html">proton::container</a>&amp; c) OVERRIDE {</div><div class="line">        c.<a name="a4"></a><a class="code" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1">connect</a>(url);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a5"></a><a class="code" href="classproton_1_1messaging__handler.html#a16ba022e899957b2e25b9561b1f53968">on_connection_open</a>(<a name="_a6"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; c) OVERRIDE {</div><div class="line">        c.<a name="a7"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(url.<a name="a8"></a><a class="code" href="classproton_1_1url.html#ac4cb5f95f1d720ef0cc94b74152cf50b">path</a>());</div><div class="line">        c.<a name="a9"></a><a class="code" href="classproton_1_1connection.html#ae8eece4f
 d4b9e1a2531ca12d2ab57a32">open_sender</a>(url.<a class="code" href="classproton_1_1url.html#ac4cb5f95f1d720ef0cc94b74152cf50b">path</a>());</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a10"></a><a class="code" href="classproton_1_1messaging__handler.html#aa24f522a68cdf382762702cece7790e7">on_sendable</a>(<a name="_a11"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;s) OVERRIDE {</div><div class="line">        <a name="_a12"></a><a class="code" href="classproton_1_1message.html">proton::message</a> m(<span class="stringliteral">&quot;Hello World!&quot;</span>);</div><div class="line">        s.<a name="a13"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">        s.<a name="a14"></a><a class="code" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">
     }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a15"></a><a class="code" href="classproton_1_1messaging__handler.html#a96879b0b0b7ade11f98d3f450abd4c46">on_message</a>(<a name="_a16"></a><a class="code" href="classproton_1_1delivery.html">proton::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m) OVERRIDE {</div><div class="line">        std::cout &lt;&lt; m.<a name="a17"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">        d.<a name="a18"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a19"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordty
 pe">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        std::string url = argc &gt; 1 ? argv[1] : <span class="stringliteral">&quot;127.0.0.1:5672/examples&quot;</span>;</div><div class="line"></div><div class="line">        hello_world hw(url);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(hw).<a name="a20"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div clas
 s="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
+<div class="fragment"><div class="line"><span class="comment">/*</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><span class="comment"> * distributed with this work for additional information</span></div><div class="line"><span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><span class="comment"> *</span></div><div class="li
 ne"><span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><span class="comment"> * under the License.</span></div><div class="line"><span class="comment"> *</span></div><div class="line"><span class="comment"> */</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" 
 href="connection_8hpp.html">proton/connection.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="container_8hpp.html">proton/container.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="delivery_8hpp.html">proton/delivery.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="message_8hpp.html">proton/message.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="messaging__handler_8hpp.html">proton/messaging_handler.hpp</a>&gt;</span></div><div class="line"><span class="preprocessor">#include &lt;<a class="code" href="tracker_8hpp.html">proton/tracker.hpp</a>&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &lt;iostream&gt;</span></div><div class="line"></div><div class="line"><span class="preprocessor">#include &quot;fake_cpp11.hpp&quot
 ;</span></div><div class="line"></div><div class="line"><span class="keyword">class </span>hello_world : <span class="keyword">public</span> <a name="_a0"></a><a class="code" href="classproton_1_1messaging__handler.html">proton::messaging_handler</a> {</div><div class="line">    std::string conn_url_;</div><div class="line">    std::string addr_;</div><div class="line"></div><div class="line">  <span class="keyword">public</span>:</div><div class="line">    hello_world(<span class="keyword">const</span> std::string&amp; u, <span class="keyword">const</span> std::string&amp; a) :</div><div class="line">        conn_url_(u), addr_(a) {}</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a1"></a><a class="code" href="classproton_1_1messaging__handler.html#a9188622c33638e076d2214080129c824">on_container_start</a>(<a name="_a2"></a><a class="code" href="classproton_1_1container.html">proton::container</a>&amp; c) OVERRIDE {</div><div class="
 line">        c.<a name="a3"></a><a class="code" href="classproton_1_1container.html#adbd9ed231804512a47cca3c81f00cdf1">connect</a>(conn_url_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a4"></a><a class="code" href="classproton_1_1messaging__handler.html#a41277abe0e33a3df2764b08dcc12d768">on_connection_open</a>(<a name="_a5"></a><a class="code" href="classproton_1_1connection.html">proton::connection</a>&amp; c) OVERRIDE {</div><div class="line">        c.<a name="a6"></a><a class="code" href="classproton_1_1connection.html#aad60d14592ee9d34caca4c61214ecd27">open_receiver</a>(addr_);</div><div class="line">        c.<a name="a7"></a><a class="code" href="classproton_1_1connection.html#ae8eece4fd4b9e1a2531ca12d2ab57a32">open_sender</a>(addr_);</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a8"></a><a class="code" href="cl
 assproton_1_1messaging__handler.html#a86c9509ba3ce1925150c5b7a9a937c94">on_sendable</a>(<a name="_a9"></a><a class="code" href="classproton_1_1sender.html">proton::sender</a> &amp;s) OVERRIDE {</div><div class="line">        <a name="_a10"></a><a class="code" href="classproton_1_1message.html">proton::message</a> m(<span class="stringliteral">&quot;Hello World!&quot;</span>);</div><div class="line">        s.<a name="a11"></a><a class="code" href="classproton_1_1sender.html#a214eb30b24e6831d016a47b9dddda830">send</a>(m);</div><div class="line">        s.<a name="a12"></a><a class="code" href="classproton_1_1link.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordtype">void</span> <a name="a13"></a><a class="code" href="classproton_1_1messaging__handler.html#a584c9daeadf4322801f58e054017fecb">on_message</a>(<a name="_a14"></a><a class="code" href="classproton_1_1delivery.html">proton
 ::delivery</a> &amp;d, <a class="code" href="classproton_1_1message.html">proton::message</a> &amp;m) OVERRIDE {</div><div class="line">        std::cout &lt;&lt; m.<a name="a15"></a><a class="code" href="classproton_1_1message.html#ae9af642f154a68ec0eb8e715ecaf95ae">body</a>() &lt;&lt; std::endl;</div><div class="line">        d.<a name="a16"></a><a class="code" href="classproton_1_1transfer.html#aff302bb6016f2ae29f01bb4e07389a52">connection</a>().<a name="a17"></a><a class="code" href="classproton_1_1connection.html#a5ae591df94fc66ccb85cbb6565368bca">close</a>();</div><div class="line">    }</div><div class="line">};</div><div class="line"></div><div class="line"><span class="keywordtype">int</span> main(<span class="keywordtype">int</span> argc, <span class="keywordtype">char</span> **argv) {</div><div class="line">    <span class="keywordflow">try</span> {</div><div class="line">        std::string conn_url = argc &gt; 1 ? argv[1] : <span class="stringliteral">&quot;//127.0.0.1:
 5672&quot;</span>;</div><div class="line">        std::string addr = argc &gt; 2 ? argv[2] : <span class="stringliteral">&quot;examples&quot;</span>;</div><div class="line"></div><div class="line">        hello_world hw(conn_url, addr);</div><div class="line">        <a class="code" href="classproton_1_1container.html">proton::container</a>(hw).<a name="a18"></a><a class="code" href="classproton_1_1container.html#a13a43e6d814de94978c515cb084873b1">run</a>();</div><div class="line"></div><div class="line">        <span class="keywordflow">return</span> 0;</div><div class="line">    } <span class="keywordflow">catch</span> (<span class="keyword">const</span> std::exception&amp; e) {</div><div class="line">        std::cerr &lt;&lt; e.what() &lt;&lt; std::endl;</div><div class="line">    }</div><div class="line"></div><div class="line">    <span class="keywordflow">return</span> 1;</div><div class="line">}</div></div><!-- fragment --> </div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->
 <div id="nav-path" class="navpath"><!-- id is needed for treeview function! -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.html b/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.html
index 796236f..c43a6c8 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.html
@@ -164,26 +164,26 @@ $(document).ready(function(){initNavTree('hierarchy.html','');});
 <tr id="row_27_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1message.html" target="_self">message</a></td><td class="desc">An AMQP message </td></tr>
 <tr id="row_28_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1messaging__handler.html" target="_self">messaging_handler</a></td><td class="desc">A handler for Proton messaging events </td></tr>
 <tr id="row_29_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="structproton_1_1io_1_1mutable__buffer.html" target="_self">mutable_buffer</a></td><td class="desc"><b>Unsettled API</b> - A pointer to a mutable memory region with a size </td></tr>
-<tr id="row_30_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver__options.html" target="_self">receiver_options</a></td><td class="desc">Options for creating a receiver </td></tr>
-<tr id="row_31_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1reconnect__options.html" target="_self">reconnect_options</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss </td></tr>
-<tr id="row_32_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1returned.html" target="_self">returned&lt; T &gt;</a></td><td class="desc">A return type for container methods </td></tr>
-<tr id="row_33_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sasl.html" target="_self">sasl</a></td><td class="desc">SASL information </td></tr>
-<tr id="row_34_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender__options.html" target="_self">sender_options</a></td><td class="desc">Options for creating a sender </td></tr>
-<tr id="row_35_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session__options.html" target="_self">session_options</a></td><td class="desc">Options for creating a session </td></tr>
-<tr id="row_36_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source__options.html" target="_self">source_options</a></td><td class="desc">Options for creating a source node for a sender or receiver </td></tr>
-<tr id="row_37_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl.html" target="_self">ssl</a></td><td class="desc">SSL information </td></tr>
-<tr id="row_38_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__certificate.html" target="_self">ssl_certificate</a></td><td class="desc"><b>Unsettled API</b> - An SSL certificate </td></tr>
-<tr id="row_39_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__client__options.html" target="_self">ssl_client_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for outbound connections </td></tr>
-<tr id="row_40_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__server__options.html" target="_self">ssl_server_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for inbound connections </td></tr>
-<tr id="row_41_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start" target="_self">start</a></td><td class="desc"><b>Unsettled API</b> - Start encoding a complex type </td></tr>
-<tr id="row_42_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target__options.html" target="_self">target_options</a></td><td class="desc">Options for creating a target node for a sender or receiver </td></tr>
-<tr id="row_43_" class="even"><td class="entry"><span style="width:0px;display:inline-block;">&#160;</span><span id="arr_43_" class="arrow" onclick="toggleFolder('43_')">&#9660;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1terminus.html" target="_self">terminus</a></td><td class="desc">One end of a link, either a source or a target </td></tr>
-<tr id="row_43_0_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source.html" target="_self">source</a></td><td class="desc">A point of origin for messages </td></tr>
-<tr id="row_43_1_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target.html" target="_self">target</a></td><td class="desc">A destination for messages </td></tr>
-<tr id="row_44_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1url.html" target="_self">url</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
-<tr id="row_45_" class="even"><td class="entry"><span style="width:0px;display:inline-block;">&#160;</span><span id="arr_45_" class="arrow" onclick="toggleFolder('45_')">&#9660;</span><span class="icona"><span class="icon">C</span></span><b>vector&lt; T &gt;</b></td><td class="desc">STL class </td></tr>
-<tr id="row_45_0_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1binary.html" target="_self">binary</a></td><td class="desc">Arbitrary binary data </td></tr>
-<tr id="row_46_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1work.html" target="_self">work</a></td><td class="desc"><b>Unsettled API</b> - A work item for a <a class="el" href="classproton_1_1work__queue.html">work queue</a> </td></tr>
+<tr id="row_30_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1null.html" target="_self">null</a></td><td class="desc">The type of the AMQP null value </td></tr>
+<tr id="row_31_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1receiver__options.html" target="_self">receiver_options</a></td><td class="desc">Options for creating a receiver </td></tr>
+<tr id="row_32_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1reconnect__options.html" target="_self">reconnect_options</a></td><td class="desc"><b>Unsettled API</b> - Options for reconnect and failover after connection loss </td></tr>
+<tr id="row_33_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1returned.html" target="_self">returned&lt; T &gt;</a></td><td class="desc">A return type for container methods </td></tr>
+<tr id="row_34_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sasl.html" target="_self">sasl</a></td><td class="desc">SASL information </td></tr>
+<tr id="row_35_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1sender__options.html" target="_self">sender_options</a></td><td class="desc">Options for creating a sender </td></tr>
+<tr id="row_36_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1session__options.html" target="_self">session_options</a></td><td class="desc">Options for creating a session </td></tr>
+<tr id="row_37_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source__options.html" target="_self">source_options</a></td><td class="desc">Options for creating a source node for a sender or receiver </td></tr>
+<tr id="row_38_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl.html" target="_self">ssl</a></td><td class="desc">SSL information </td></tr>
+<tr id="row_39_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__certificate.html" target="_self">ssl_certificate</a></td><td class="desc"><b>Unsettled API</b> - An SSL certificate </td></tr>
+<tr id="row_40_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__client__options.html" target="_self">ssl_client_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for outbound connections </td></tr>
+<tr id="row_41_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1ssl__server__options.html" target="_self">ssl_server_options</a></td><td class="desc"><b>Unsettled API</b> - SSL configuration for inbound connections </td></tr>
+<tr id="row_42_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="namespaceproton_1_1codec.html#structproton_1_1codec_1_1start" target="_self">start</a></td><td class="desc"><b>Unsettled API</b> - Start encoding a complex type </td></tr>
+<tr id="row_43_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target__options.html" target="_self">target_options</a></td><td class="desc">Options for creating a target node for a sender or receiver </td></tr>
+<tr id="row_44_"><td class="entry"><span style="width:0px;display:inline-block;">&#160;</span><span id="arr_44_" class="arrow" onclick="toggleFolder('44_')">&#9660;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1terminus.html" target="_self">terminus</a></td><td class="desc">One end of a link, either a source or a target </td></tr>
+<tr id="row_44_0_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1source.html" target="_self">source</a></td><td class="desc">A point of origin for messages </td></tr>
+<tr id="row_44_1_"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1target.html" target="_self">target</a></td><td class="desc">A destination for messages </td></tr>
+<tr id="row_45_" class="even"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1url.html" target="_self">url</a></td><td class="desc"><b>Deprecated</b> - Use a third-party URL library </td></tr>
+<tr id="row_46_"><td class="entry"><span style="width:0px;display:inline-block;">&#160;</span><span id="arr_46_" class="arrow" onclick="toggleFolder('46_')">&#9660;</span><span class="icona"><span class="icon">C</span></span><b>vector&lt; T &gt;</b></td><td class="desc">STL class </td></tr>
+<tr id="row_46_0_" class="even"><td class="entry"><span style="width:32px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1binary.html" target="_self">binary</a></td><td class="desc">Arbitrary binary data </td></tr>
 <tr id="row_47_"><td class="entry"><span style="width:16px;display:inline-block;">&#160;</span><span class="icona"><span class="icon">C</span></span><a class="el" href="classproton_1_1work__queue.html" target="_self">work_queue</a></td><td class="desc"><b>Unsettled API</b> - A context for thread-safe execution of work </td></tr>
 </table>
 </div><!-- directory -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.js b/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.js
index cda5ba5..0407e1f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.js
+++ b/content/releases/qpid-proton-master/proton/cpp/api/hierarchy.js
@@ -96,6 +96,7 @@ var hierarchy =
     [ "message", "classproton_1_1message.html", null ],
     [ "messaging_handler", "classproton_1_1messaging__handler.html", null ],
     [ "mutable_buffer", "structproton_1_1io_1_1mutable__buffer.html", null ],
+    [ "null", "classproton_1_1null.html", null ],
     [ "receiver_options", "classproton_1_1receiver__options.html", null ],
     [ "reconnect_options", "classproton_1_1reconnect__options.html", null ],
     [ "returned< T >", "classproton_1_1returned.html", null ],
@@ -117,6 +118,5 @@ var hierarchy =
     [ "vector< T >", null, [
       [ "binary", "classproton_1_1binary.html", null ]
     ] ],
-    [ "work", "classproton_1_1work.html", null ],
     [ "work_queue", "classproton_1_1work__queue.html", null ]
 ];
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/index.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/index.html b/content/releases/qpid-proton-master/proton/cpp/api/index.html
index 2f552e8..0937362 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/index.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/index.html
@@ -106,12 +106,12 @@ $(document).ready(function(){initNavTree('index.html','');});
 <p>Elements of the API marked as <b>Unsettled API</b>, including any elements contained within them, are still evolving and thus are subject to change. They are available to use, but newer versions of Proton may require changes to your application source code.</p>
 <p>Elements marked <b>Deprecated</b> are slated for removal in a future release.</p>
 <p>Sections labeled <b>Thread safety</b> describe when and where it is safe to call functions or access data across threads.</p>
-<p>Sections called <b>C++ versions</b> discuss features the API that depend on particular versions of C++ such as C++11.</p>
+<p>Sections called <b>C++ versions</b> discuss features of the API that depend on particular versions of C++ such as C++11.</p>
 <h2>URLs</h2>
 <p>The API uses URLs to identify three different kinds of resources. All URL argument names are suffixed with <code>_url</code>.</p>
 <p>Connection URLs (<code>conn_url</code> in argument lists) specify a target for outgoing network connections. The path part of the URL is ignored.</p>
 <p>Address URLs (<code>addr_url</code>) extend the connection URL to reference an AMQP node such as a queue or topic. The path of the URL, minus the leading slash, is treated as the AMQP address of the node.</p>
-<p>Listener URLs (<code>listen_url</code>) specify a local network address and port for accepting incoming TCP connections. </p>
+<p>Listener URLs (<code>listen_url</code>) specify a local network address and port for accepting incoming TCP connections. The path part of the URL is ignored. The host part may be empty, meaning "listen on all available interfaces". </p>
 </div></div><!-- contents -->
 </div><!-- doc-content -->
 <!-- start footer part -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/link_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/link_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/link_8hpp_source.html
index 4802003..8a059b0 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/link_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/link_8hpp_source.html
@@ -93,14 +93,14 @@ $(document).ready(function(){initNavTree('link_8hpp_source.html','');});
 <div class="title">link.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="link_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LINK_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LINK_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreemen
 ts.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="com
 ment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div
 ><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="
 l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="endpoint_8hpp.html">./endpoint.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/object.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">struct </span>pn_link_t;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno
 ">   37</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno"><a class="line" href="classproton_1_1link.html">   41</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1link.html">link</a> : <span class="keyword">public</span> internal::object&lt;pn_link_t&gt; , <span class="keyword">public</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    <a class="code" href="classproton_1_1link.html">link</a>(pn_link_t* l) : internal::object&lt;pn_link_t&gt;(l) {}</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><
 div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="classproton_1_1link.html#ad29b379b3621ec393ac9f28b4ba8b010">   49</a></span>&#160;    <a class="code" href="classproton_1_1link.html#ad29b379b3621ec393ac9f28b4ba8b010">link</a>() : internal::object&lt;pn_link_t&gt;(0) {}</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</span>;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> active() <span class="keyword">const</span>;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    PN_CPP_EXTERN <span class="
 keywordtype">bool</span> closed() <span class="keyword">const</span>;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close();</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a nam
 e="l00064"></a><span class="lineno">   64</span>&#160;    <span class="comment">// XXX Should take error condition</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> detach();</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">int</span> credit() <span class="keyword">const</span>;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> draining();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN std::string name() <span class="keyword
 ">const</span>;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a> &amp;<a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>&amp; <a class="code" href="classproton_1_1work__queue.html">work_queue</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    PN_CPP_EXT
 ERN <span class="keyword">class </span><a class="code" href="classproton_1_1connection.html">connection</a> connection() const;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1session.html">session</a> session() const;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;  <span class="keyword">protected</span>:</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    </div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    <span class="comment">// Initiate the AMQP attach frame.</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    <span class="keywordtype">void</sp
 an> attach();</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;link&gt;;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;};</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;}</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor">#endif // PROTON_LINK_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><d
 iv class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<a href="link_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LINK_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LINK_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license agreemen
 ts.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span class="com
 ment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div
 ><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="
 l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="endpoint_8hpp.html">./endpoint.hpp</a>&quot;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &quot;./internal/object.hpp&quot;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;<span class="keyword">struct </span>pn_link_t;</div><div class="line"><a name="l00036"></a><span class="lineno">   36</span>&#160;</div><div class="line"><a name="l00037"></a><span class="lineno
 ">   37</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;</div><div class="line"><a name="l00041"></a><span class="lineno"><a class="line" href="classproton_1_1link.html">   41</a></span>&#160;<span class="keyword">class</span></div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1link.html">link</a> : <span class="keyword">public</span> internal::object&lt;pn_link_t&gt; , <span class="keyword">public</span> <a class="code" href="classproton_1_1endpoint.html">endpoint</a> {</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    <a class="code" href="classproton_1_1link.html">link</a>(pn_link_t* l) : internal::object&lt;pn_link_t&gt;(l) {}</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><
 div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00049"></a><span class="lineno"><a class="line" href="classproton_1_1link.html#ad29b379b3621ec393ac9f28b4ba8b010">   49</a></span>&#160;    <a class="code" href="classproton_1_1link.html#ad29b379b3621ec393ac9f28b4ba8b010">link</a>() : internal::object&lt;pn_link_t&gt;(0) {}</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> uninitialized() <span class="keyword">const</span>;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> active() <span class="keyword">const</span>;</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;    PN_CPP_EXTERN <span class="
 keywordtype">bool</span> closed() <span class="keyword">const</span>;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1error__condition.html">error_condition</a> error() const;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close();</div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> close(<span class="keyword">const</span> <a class="code" href="classproton_1_1error__condition.html">error_condition</a>&amp;);</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;</div><div class="line"><a nam
 e="l00064"></a><span class="lineno">   64</span>&#160;    <span class="comment">// XXX Should take error condition</span></div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> detach();</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">int</span> credit() <span class="keyword">const</span>;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00076"></a><span class="lineno">   76</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">bool</span> draining();</div><div class="line"><a name="l00077"></a><span class="lineno">   77</span>&#160;</div><div class="line"><a name="l00079"></a><span class="lineno">   79</span>&#160;    PN_CPP_EXTERN std::string name() <span class="keyword
 ">const</span>;</div><div class="line"><a name="l00080"></a><span class="lineno">   80</span>&#160;</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a> &amp;<a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00083"></a><span class="lineno">   83</span>&#160;</div><div class="line"><a name="l00085"></a><span class="lineno">   85</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1work__queue.html">work_queue</a>&amp; <a class="code" href="classproton_1_1work__queue.html">work_queue</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00086"></a><span class="lineno">   86</span>&#160;</div><div class="line"><a name="l00088"></a><span class="lineno">   88</span>&#160;    PN_CPP_EXT
 ERN <span class="keyword">class </span><a class="code" href="classproton_1_1connection.html">connection</a> connection() const;</div><div class="line"><a name="l00089"></a><span class="lineno">   89</span>&#160;</div><div class="line"><a name="l00091"></a><span class="lineno">   91</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1session.html">session</a> session() const;</div><div class="line"><a name="l00092"></a><span class="lineno">   92</span>&#160;</div><div class="line"><a name="l00093"></a><span class="lineno">   93</span>&#160;  <span class="keyword">protected</span>:</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;    </div><div class="line"><a name="l00096"></a><span class="lineno">   96</span>&#160;    <span class="comment">// Initiate the AMQP attach frame.</span></div><div class="line"><a name="l00097"></a><span class="lineno">   97</span>&#160;    <span class="keywordtype">void</sp
 an> attach();</div><div class="line"><a name="l00098"></a><span class="lineno">   98</span>&#160;</div><div class="line"><a name="l00099"></a><span class="lineno">   99</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>internal::factory&lt;link&gt;;</div><div class="line"><a name="l00100"></a><span class="lineno">  100</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;};</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00104"></a><span class="lineno">  104</span>&#160;}</div><div class="line"><a name="l00105"></a><span class="lineno">  105</span>&#160;</div><div class="line"><a name="l00106"></a><span class="lineno">  106</span>&#160;<span class="preprocessor">#endif // PROTON_LINK_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><d
 iv class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
 <div class="ttc" id="classproton_1_1link_html"><div class="ttname"><a href="classproton_1_1link.html">proton::link</a></div><div class="ttdoc">A named channel for sending or receiving messages. </div><div class="ttdef"><b>Definition:</b> link.hpp:41</div></div>
 <div class="ttc" id="classproton_1_1connection_html"><div class="ttname"><a href="classproton_1_1connection.html">proton::connection</a></div><div class="ttdoc">A connection to a remote AMQP peer. </div><div class="ttdef"><b>Definition:</b> connection.hpp:43</div></div>
 <div class="ttc" id="classproton_1_1endpoint_html"><div class="ttname"><a href="classproton_1_1endpoint.html">proton::endpoint</a></div><div class="ttdoc">The base class for session, connection, and link. </div><div class="ttdef"><b>Definition:</b> endpoint.hpp:36</div></div>
 <div class="ttc" id="classproton_1_1session_html"><div class="ttname"><a href="classproton_1_1session.html">proton::session</a></div><div class="ttdoc">A container of senders and receivers. </div><div class="ttdef"><b>Definition:</b> session.hpp:41</div></div>
 <div class="ttc" id="classproton_1_1link_html_ad29b379b3621ec393ac9f28b4ba8b010"><div class="ttname"><a href="classproton_1_1link.html#ad29b379b3621ec393ac9f28b4ba8b010">proton::link::link</a></div><div class="ttdeci">link()</div><div class="ttdoc">Create an empty link. </div><div class="ttdef"><b>Definition:</b> link.hpp:49</div></div>
-<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:94</div></div>
+<div class="ttc" id="classproton_1_1work__queue_html"><div class="ttname"><a href="classproton_1_1work__queue.html">proton::work_queue</a></div><div class="ttdoc">Unsettled API - A context for thread-safe execution of work. </div><div class="ttdef"><b>Definition:</b> work_queue.hpp:339</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 <div class="ttc" id="endpoint_8hpp_html"><div class="ttname"><a href="endpoint_8hpp.html">endpoint.hpp</a></div><div class="ttdoc">The base class for session, connection, and link. </div></div>
 <div class="ttc" id="classproton_1_1error__condition_html"><div class="ttname"><a href="classproton_1_1error__condition.html">proton::error_condition</a></div><div class="ttdoc">Describes an endpoint error state. </div><div class="ttdef"><b>Definition:</b> error_condition.hpp:40</div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp.html b/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp.html
index 549bd0a..ff96c1d 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp.html
@@ -100,6 +100,8 @@ $(document).ready(function(){initNavTree('listen__handler_8hpp.html','');});
 <p><b>Unsettled API</b> - A handler for incoming connections.  
 <a href="#details">More...</a></p>
 <div class="textblock"><code>#include &quot;<a class="el" href="fwd_8hpp_source.html">./fwd.hpp</a>&quot;</code><br />
+<code>#include &quot;./internal/export.hpp&quot;</code><br />
+<code>#include &lt;string&gt;</code><br />
 </div>
 <p><a href="listen__handler_8hpp_source.html">Go to the source code of this file.</a></p>
 <table class="memberdecls">


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


[46/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/delivery_8h_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/delivery_8h_source.html b/content/releases/qpid-proton-master/proton/c/api/delivery_8h_source.html
index 541e85a..255ad02 100755
--- a/content/releases/qpid-proton-master/proton/c/api/delivery_8h_source.html
+++ b/content/releases/qpid-proton-master/proton/c/api/delivery_8h_source.html
@@ -93,13 +93,13 @@ $(document).ready(function(){initNavTree('delivery_8h_source.html','');});
 <div class="title">delivery.h</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="delivery_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DELIVERY_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DELIVERY_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license 
 agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</sp
 an></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="disposition_8h.html">proton/disposition.h</a>&gt;</span></div><div clas
 s="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno"><a class="line" href="group__delivery.html#ga08515
 9cb4136f84a02777bcc72c73fa3">   46</a></span>&#160;<span class="keyword">typedef</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> <a class="code" href="group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3">pn_delivery_tag_t</a>;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PN_EXTERN pn_delivery_tag_t <a class="code" href="group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__delivery.
 html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, pn_delivery_tag_t tag);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9
 f9a0478f340">pn_delivery_t</a> *delivery, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN pn_delivery_tag_t <a class="code" href="group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5">pn_delivery_tag</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div cla
 ss="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1">pn_disposition_t</a> *<a class="code" href="group__delivery.html#ga404728c55cb6984dbb51956d764265a0">pn_delivery_local</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00137"></a><s
 pan class="lineno">  137</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898">pn_delivery_local_state</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1">pn_disposition_t</a> *<a class="code" href="group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f">pn_delivery_remote</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__delivery.html#gac1c3f
 2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga516aee25357ac7cfde863bbceef02529">pn_delivery_settled</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_d
 elivery_t</a> *delivery);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00199"></a><span class="lineno">  199</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery); <span class="comment">/* FIXME aconway 2017-09-11:  */</span></div><div class="line"><a name="l00200"></a><span class
 ="lineno">  200</span>&#160;</div><div class="line"><a name="l00210"></a><span class="lineno">  210</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">pn_delivery_writable</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00211"></a><span class="lineno">  211</span>&#160;</div><div class="line"><a name="l00221"></a><span class="lineno">  221</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00222"></a><span class="lineno">  222</span>&#160;</div><div class="line"><a name="l00233"></a><span class="lineno">  233</span>&#160;PN_EXTERN <span class="keywor
 dtype">bool</span> <a class="code" href="group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9">pn_delivery_updated</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00234"></a><span class="lineno">  234</span>&#160;</div><div class="line"><a name="l00244"></a><span class="lineno">  244</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery, uint64_t state);</div><div class="line"><a name="l00245"></a><span class="lineno">  245</span>&#160;</div><div class="line"><a name="l00253"></a><span class="lineno">  253</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b">pn_delivery_clear</a>(<a class
 ="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00254"></a><span class="lineno">  254</span>&#160;</div><div class="line"><a name="l00261"></a><span class="lineno">  261</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33">pn_delivery_current</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00262"></a><span class="lineno">  262</span>&#160;</div><div class="line"><a name="l00275"></a><span class="lineno">  275</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00276"></a>
 <span class="lineno">  276</span>&#160;</div><div class="line"><a name="l00287"></a><span class="lineno">  287</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00288"></a><span class="lineno">  288</span>&#160;</div><div class="line"><a name="l00294"></a><span class="lineno">  294</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb">pn_delivery_dump</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00295"></a><span class="lineno">  295</span>&#160;</div><div class="line"><a name="l00308"></a><span class="lineno">  308</span>&#160;PN_EXTERN <span class="k
 eywordtype">bool</span> <a class="code" href="group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf">pn_delivery_buffered</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00309"></a><span class="lineno">  309</span>&#160;</div><div class="line"><a name="l00326"></a><span class="lineno">  326</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac">pn_work_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00327"></a><span class="lineno">  327</span>&#160;</div><div class="line"><a name="l00337"></a><span class="lineno">  337</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> 
 *<a class="code" href="group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd">pn_work_next</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00338"></a><span class="lineno">  338</span>&#160;</div><div class="line"><a name="l00343"></a><span class="lineno">  343</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00344"></a><span class="lineno">  344</span>&#160;}</div><div class="line"><a name="l00345"></a><span class="lineno">  345</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00346"></a><span class="lineno">  346</span>&#160;</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* delivery.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__delivery_html_ga3e014fc1759a212bc3ee9e513
 a274331"><div class="ttname"><a href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a></div><div class="ttdeci">pn_record_t * pn_delivery_attachments(pn_delivery_t *delivery)</div><div class="ttdoc">Get the attachments that are associated with a delivery object. </div></div>
-<div class="ttc" id="group__delivery_html_ga91519d3e4568ee8b622d3653e20f60a6"><div class="ttname"><a href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a></div><div class="ttdeci">void pn_delivery_set_context(pn_delivery_t *delivery, void *context)</div></div>
+<a href="delivery_8h.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_DELIVERY_H</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_DELIVERY_H 1</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or more contributor license 
 agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<span cl
 ass="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</sp
 an></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &lt;proton/import_export.h&gt;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &lt;<a class="code" href="disposition_8h.html">proton/disposition.h</a>&gt;</span></div><div clas
 s="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;proton/type_compat.h&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="preprocessor">#include &lt;stddef.h&gt;</span></div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;<span class="keyword">extern</span> <span class="stringliteral">&quot;C&quot;</span> {</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno"><a class="line" href="group__delivery.html#ga08515
 9cb4136f84a02777bcc72c73fa3">   46</a></span>&#160;<span class="keyword">typedef</span> <a class="code" href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a> <a class="code" href="group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3">pn_delivery_tag_t</a>;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;PN_EXTERN pn_delivery_tag_t <a class="code" href="group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a>(<span class="keyword">const</span> <span class="keywordtype">char</span> *bytes, <span class="keywordtype">size_t</span> size);</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__delivery.
 html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a>(<a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *link, pn_delivery_tag_t tag);</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00081"></a><span class="lineno">   81</span>&#160;PN_EXTERN <span class="keywordtype">void</span> *<a class="code" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00082"></a><span class="lineno">   82</span>&#160;</div><div class="line"><a name="l00094"></a><span class="lineno">   94</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9
 f9a0478f340">pn_delivery_t</a> *delivery, <span class="keywordtype">void</span> *context);</div><div class="line"><a name="l00095"></a><span class="lineno">   95</span>&#160;</div><div class="line"><a name="l00102"></a><span class="lineno">  102</span>&#160;PN_EXTERN pn_record_t *<a class="code" href="group__delivery.html#ga3e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00103"></a><span class="lineno">  103</span>&#160;</div><div class="line"><a name="l00110"></a><span class="lineno">  110</span>&#160;PN_EXTERN pn_delivery_tag_t <a class="code" href="group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5">pn_delivery_tag</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00111"></a><span class="lineno">  111</span>&#160;</div><div cla
 ss="line"><a name="l00118"></a><span class="lineno">  118</span>&#160;PN_EXTERN <a class="code" href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a> *<a class="code" href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00119"></a><span class="lineno">  119</span>&#160;</div><div class="line"><a name="l00129"></a><span class="lineno">  129</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1">pn_disposition_t</a> *<a class="code" href="group__delivery.html#ga404728c55cb6984dbb51956d764265a0">pn_delivery_local</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00130"></a><span class="lineno">  130</span>&#160;</div><div class="line"><a name="l00137"></a><s
 pan class="lineno">  137</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898">pn_delivery_local_state</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00138"></a><span class="lineno">  138</span>&#160;</div><div class="line"><a name="l00148"></a><span class="lineno">  148</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1">pn_disposition_t</a> *<a class="code" href="group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f">pn_delivery_remote</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00149"></a><span class="lineno">  149</span>&#160;</div><div class="line"><a name="l00156"></a><span class="lineno">  156</span>&#160;PN_EXTERN uint64_t <a class="code" href="group__delivery.html#gac1c3f
 2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00157"></a><span class="lineno">  157</span>&#160;</div><div class="line"><a name="l00164"></a><span class="lineno">  164</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga516aee25357ac7cfde863bbceef02529">pn_delivery_settled</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00165"></a><span class="lineno">  165</span>&#160;</div><div class="line"><a name="l00172"></a><span class="lineno">  172</span>&#160;PN_EXTERN <span class="keywordtype">size_t</span> <a class="code" href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_d
 elivery_t</a> *delivery);</div><div class="line"><a name="l00173"></a><span class="lineno">  173</span>&#160;</div><div class="line"><a name="l00183"></a><span class="lineno">  183</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00184"></a><span class="lineno">  184</span>&#160;</div><div class="line"><a name="l00203"></a><span class="lineno">  203</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00204"></a><span class="lineno">  204</span>&#160;</div><div class="line"><a name="l
 00214"></a><span class="lineno">  214</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">pn_delivery_writable</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00215"></a><span class="lineno">  215</span>&#160;</div><div class="line"><a name="l00225"></a><span class="lineno">  225</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00226"></a><span class="lineno">  226</span>&#160;</div><div class="line"><a name="l00237"></a><span class="lineno">  237</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#
 ga56d7f16a93e5dd16147a2ecd4896fcb9">pn_delivery_updated</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00238"></a><span class="lineno">  238</span>&#160;</div><div class="line"><a name="l00248"></a><span class="lineno">  248</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery, uint64_t state);</div><div class="line"><a name="l00249"></a><span class="lineno">  249</span>&#160;</div><div class="line"><a name="l00257"></a><span class="lineno">  257</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b">pn_delivery_clear</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0
 478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00258"></a><span class="lineno">  258</span>&#160;</div><div class="line"><a name="l00265"></a><span class="lineno">  265</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33">pn_delivery_current</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00266"></a><span class="lineno">  266</span>&#160;</div><div class="line"><a name="l00284"></a><span class="lineno">  284</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00285"></a><span class="lineno">  285</span>&#160;</div><div class="line"
 ><a name="l00296"></a><span class="lineno">  296</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga98c275fd7158e8b9d7d48d70503d68df">pn_delivery_settle</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00297"></a><span class="lineno">  297</span>&#160;</div><div class="line"><a name="l00303"></a><span class="lineno">  303</span>&#160;PN_EXTERN <span class="keywordtype">void</span> <a class="code" href="group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb">pn_delivery_dump</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00304"></a><span class="lineno">  304</span>&#160;</div><div class="line"><a name="l00317"></a><span class="lineno">  317</span>&#160;PN_EXTERN <span class="keywordtype">bool</span> <a class="code" href="group__delivery.
 html#ga1b7d56bd985e12a524c5cc5bc969bbdf">pn_delivery_buffered</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00318"></a><span class="lineno">  318</span>&#160;</div><div class="line"><a name="l00335"></a><span class="lineno">  335</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac">pn_work_head</a>(<a class="code" href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a> *connection);</div><div class="line"><a name="l00336"></a><span class="lineno">  336</span>&#160;</div><div class="line"><a name="l00346"></a><span class="lineno">  346</span>&#160;PN_EXTERN <a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *<a class="code" href="group__delivery.html#gad7b9248f26e47879
 83378e5310e4ffdd">pn_work_next</a>(<a class="code" href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a> *delivery);</div><div class="line"><a name="l00347"></a><span class="lineno">  347</span>&#160;</div><div class="line"><a name="l00352"></a><span class="lineno">  352</span>&#160;<span class="preprocessor">#ifdef __cplusplus</span></div><div class="line"><a name="l00353"></a><span class="lineno">  353</span>&#160;}</div><div class="line"><a name="l00354"></a><span class="lineno">  354</span>&#160;<span class="preprocessor">#endif</span></div><div class="line"><a name="l00355"></a><span class="lineno">  355</span>&#160;</div><div class="line"><a name="l00356"></a><span class="lineno">  356</span>&#160;<span class="preprocessor">#endif </span><span class="comment">/* delivery.h */</span><span class="preprocessor"></span></div><div class="ttc" id="group__delivery_html_ga3e014fc1759a212bc3ee9e513a274331"><div class="ttname"><a href="group__delivery.html#ga3
 e014fc1759a212bc3ee9e513a274331">pn_delivery_attachments</a></div><div class="ttdeci">pn_record_t * pn_delivery_attachments(pn_delivery_t *delivery)</div><div class="ttdoc">Get the attachments that are associated with a delivery object. </div></div>
+<div class="ttc" id="group__delivery_html_ga91519d3e4568ee8b622d3653e20f60a6"><div class="ttname"><a href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a></div><div class="ttdeci">void pn_delivery_set_context(pn_delivery_t *delivery, void *context)</div><div class="ttdoc">Deprecated - Use pn_delivery_attachments(). </div></div>
 <div class="ttc" id="group__delivery_html_ga56d7f16a93e5dd16147a2ecd4896fcb9"><div class="ttname"><a href="group__delivery.html#ga56d7f16a93e5dd16147a2ecd4896fcb9">pn_delivery_updated</a></div><div class="ttdeci">bool pn_delivery_updated(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a delivery is updated. </div></div>
 <div class="ttc" id="group__delivery_html_ga533bd8dd766786695b6e71f8505252f1"><div class="ttname"><a href="group__delivery.html#ga533bd8dd766786695b6e71f8505252f1">pn_delivery_writable</a></div><div class="ttdeci">bool pn_delivery_writable(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a delivery is writable. </div></div>
 <div class="ttc" id="group__delivery_html_gaee6fa7698d4b7cf335c2d7a4c7622898"><div class="ttname"><a href="group__delivery.html#gaee6fa7698d4b7cf335c2d7a4c7622898">pn_delivery_local_state</a></div><div class="ttdeci">uint64_t pn_delivery_local_state(pn_delivery_t *delivery)</div><div class="ttdoc">Get the local disposition state for a delivery. </div></div>
-<div class="ttc" id="group__delivery_html_ga712690e0cc84419d7b7ca7c49a10b776"><div class="ttname"><a href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a></div><div class="ttdeci">bool pn_delivery_aborted(pn_delivery_t *delivery)</div><div class="ttdoc">On the receiving side, check if the delivery has been aborted. </div></div>
-<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:313</div></div>
+<div class="ttc" id="group__delivery_html_ga712690e0cc84419d7b7ca7c49a10b776"><div class="ttname"><a href="group__delivery.html#ga712690e0cc84419d7b7ca7c49a10b776">pn_delivery_aborted</a></div><div class="ttdeci">bool pn_delivery_aborted(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a received delivery has been aborted. </div></div>
+<div class="ttc" id="group__link_html_ga89dad3aa7934329a7ff467c636687bc0"><div class="ttname"><a href="group__link.html#ga89dad3aa7934329a7ff467c636687bc0">pn_link_t</a></div><div class="ttdeci">struct pn_link_t pn_link_t</div><div class="ttdoc">An AMQP Link object. </div><div class="ttdef"><b>Definition:</b> types.h:311</div></div>
 <div class="ttc" id="group__delivery_html_ga365b3efbdd225a239dcf4746127c5f33"><div class="ttname"><a href="group__delivery.html#ga365b3efbdd225a239dcf4746127c5f33">pn_delivery_current</a></div><div class="ttdeci">bool pn_delivery_current(pn_delivery_t *delivery)</div><div class="ttdoc">Return true if delivery is the current delivery for its link. </div></div>
 <div class="ttc" id="group__delivery_html_ga1b7d56bd985e12a524c5cc5bc969bbdf"><div class="ttname"><a href="group__delivery.html#ga1b7d56bd985e12a524c5cc5bc969bbdf">pn_delivery_buffered</a></div><div class="ttdeci">bool pn_delivery_buffered(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a delivery is buffered. </div></div>
 <div class="ttc" id="group__delivery_html_ga404728c55cb6984dbb51956d764265a0"><div class="ttname"><a href="group__delivery.html#ga404728c55cb6984dbb51956d764265a0">pn_delivery_local</a></div><div class="ttdeci">pn_disposition_t * pn_delivery_local(pn_delivery_t *delivery)</div><div class="ttdoc">Get the local disposition for a delivery. </div></div>
@@ -107,21 +107,21 @@ $(document).ready(function(){initNavTree('delivery_8h_source.html','');});
 <div class="ttc" id="group__delivery_html_ga6b4029fa3c5a04c3e2320b9fdd0a76c5"><div class="ttname"><a href="group__delivery.html#ga6b4029fa3c5a04c3e2320b9fdd0a76c5">pn_delivery_tag</a></div><div class="ttdeci">pn_delivery_tag_t pn_delivery_tag(pn_delivery_t *delivery)</div><div class="ttdoc">Get the tag for a delivery object. </div></div>
 <div class="ttc" id="group__delivery_html_ga570c54003c2ba18b84405737925e5176"><div class="ttname"><a href="group__delivery.html#ga570c54003c2ba18b84405737925e5176">pn_delivery_update</a></div><div class="ttdeci">void pn_delivery_update(pn_delivery_t *delivery, uint64_t state)</div><div class="ttdoc">Update the disposition of a delivery. </div></div>
 <div class="ttc" id="group__delivery_html_gac1c3f2e7217b51f0e2f8c4264b0689d1"><div class="ttname"><a href="group__delivery.html#gac1c3f2e7217b51f0e2f8c4264b0689d1">pn_delivery_remote_state</a></div><div class="ttdeci">uint64_t pn_delivery_remote_state(pn_delivery_t *delivery)</div><div class="ttdoc">Get the remote disposition state for a delivery. </div></div>
-<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:403</div></div>
+<div class="ttc" id="group__delivery_html_gacdfce854066c0a4ff4db9f9a0478f340"><div class="ttname"><a href="group__delivery.html#gacdfce854066c0a4ff4db9f9a0478f340">pn_delivery_t</a></div><div class="ttdeci">struct pn_delivery_t pn_delivery_t</div><div class="ttdoc">An AMQP Delivery object. </div><div class="ttdef"><b>Definition:</b> types.h:401</div></div>
 <div class="ttc" id="group__delivery_html_ga4b28f6cd033babd8a7595fc5d292dca1"><div class="ttname"><a href="group__delivery.html#ga4b28f6cd033babd8a7595fc5d292dca1">pn_disposition_t</a></div><div class="ttdeci">struct pn_disposition_t pn_disposition_t</div><div class="ttdoc">A delivery state. </div><div class="ttdef"><b>Definition:</b> disposition.h:52</div></div>
 <div class="ttc" id="group__delivery_html_ga0dbbc51564aea5b181d161ee7add1ddb"><div class="ttname"><a href="group__delivery.html#ga0dbbc51564aea5b181d161ee7add1ddb">pn_delivery_dump</a></div><div class="ttdeci">void pn_delivery_dump(pn_delivery_t *delivery)</div><div class="ttdoc">Utility function for printing details of a delivery. </div></div>
 <div class="ttc" id="group__delivery_html_ga23c7b3c678228ccb21378e7c8ec9a72d"><div class="ttname"><a href="group__delivery.html#ga23c7b3c678228ccb21378e7c8ec9a72d">pn_delivery_partial</a></div><div class="ttdeci">bool pn_delivery_partial(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a delivery only has partial message data. </div></div>
-<div class="ttc" id="group__delivery_html_ga407e51ff91368568d15f938b1771357c"><div class="ttname"><a href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a></div><div class="ttdeci">void pn_delivery_abort(pn_delivery_t *delivery)</div><div class="ttdoc">On the sending side, abort a delivery. </div></div>
+<div class="ttc" id="group__delivery_html_ga407e51ff91368568d15f938b1771357c"><div class="ttname"><a href="group__delivery.html#ga407e51ff91368568d15f938b1771357c">pn_delivery_abort</a></div><div class="ttdeci">void pn_delivery_abort(pn_delivery_t *delivery)</div><div class="ttdoc">Abort a delivery being sent. </div></div>
 <div class="ttc" id="group__delivery_html_gad3dd82fe9a649d70d4f3430c34699638"><div class="ttname"><a href="group__delivery.html#gad3dd82fe9a649d70d4f3430c34699638">pn_delivery_link</a></div><div class="ttdeci">pn_link_t * pn_delivery_link(pn_delivery_t *delivery)</div><div class="ttdoc">Get the parent link for a delivery object. </div></div>
-<div class="ttc" id="group__delivery_html_ga17c16f34252597f9e737efae1e2ebb81"><div class="ttname"><a href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a></div><div class="ttdeci">void * pn_delivery_get_context(pn_delivery_t *delivery)</div></div>
+<div class="ttc" id="group__delivery_html_ga17c16f34252597f9e737efae1e2ebb81"><div class="ttname"><a href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a></div><div class="ttdeci">void * pn_delivery_get_context(pn_delivery_t *delivery)</div><div class="ttdoc">Deprecated - Use pn_delivery_attachments(). </div></div>
 <div class="ttc" id="group__delivery_html_ga2a666cb1a4cec190f0c9d20a7bcfae3f"><div class="ttname"><a href="group__delivery.html#ga2a666cb1a4cec190f0c9d20a7bcfae3f">pn_delivery_remote</a></div><div class="ttdeci">pn_disposition_t * pn_delivery_remote(pn_delivery_t *delivery)</div><div class="ttdoc">Get the remote disposition for a delivery. </div></div>
 <div class="ttc" id="group__delivery_html_ga2e5da4adf0738458ba8568d894e6ea5b"><div class="ttname"><a href="group__delivery.html#ga2e5da4adf0738458ba8568d894e6ea5b">pn_delivery_clear</a></div><div class="ttdeci">void pn_delivery_clear(pn_delivery_t *delivery)</div><div class="ttdoc">Clear the updated flag for a delivery. </div></div>
 <div class="ttc" id="group__delivery_html_ga13364206124b653b90f5ee3ddae9ff35"><div class="ttname"><a href="group__delivery.html#ga13364206124b653b90f5ee3ddae9ff35">pn_delivery_readable</a></div><div class="ttdeci">bool pn_delivery_readable(pn_delivery_t *delivery)</div><div class="ttdoc">Check if a delivery is readable. </div></div>
-<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:283</div></div>
+<div class="ttc" id="group__connection_html_ga886351d81ff3a977a284a206526c5aff"><div class="ttname"><a href="group__connection.html#ga886351d81ff3a977a284a206526c5aff">pn_connection_t</a></div><div class="ttdeci">struct pn_connection_t pn_connection_t</div><div class="ttdoc">An AMQP Connection object. </div><div class="ttdef"><b>Definition:</b> types.h:281</div></div>
 <div class="ttc" id="group__delivery_html_ga6a7ef2e317b4ed292cafbb358f0ba6ad"><div class="ttname"><a href="group__delivery.html#ga6a7ef2e317b4ed292cafbb358f0ba6ad">pn_delivery</a></div><div class="ttdeci">pn_delivery_t * pn_delivery(pn_link_t *link, pn_delivery_tag_t tag)</div><div class="ttdoc">Create a delivery on a link. </div></div>
 <div class="ttc" id="group__delivery_html_ga085159cb4136f84a02777bcc72c73fa3"><div class="ttname"><a href="group__delivery.html#ga085159cb4136f84a02777bcc72c73fa3">pn_delivery_tag_t</a></div><div class="ttdeci">pn_bytes_t pn_delivery_tag_t</div><div class="ttdoc">An AMQP delivery tag. </div><div class="ttdef"><b>Definition:</b> delivery.h:46</div></div>
 <div class="ttc" id="group__delivery_html_gad7b9248f26e4787983378e5310e4ffdd"><div class="ttname"><a href="group__delivery.html#gad7b9248f26e4787983378e5310e4ffdd">pn_work_next</a></div><div class="ttdeci">pn_delivery_t * pn_work_next(pn_delivery_t *delivery)</div><div class="ttdoc">Get the next delivery on the connection that needs has pending operations. </div></div>
-<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:214</div></div>
+<div class="ttc" id="group__api__types_html_structpn__bytes__t"><div class="ttname"><a href="group__api__types.html#structpn__bytes__t">pn_bytes_t</a></div><div class="ttdoc">A const byte buffer. </div><div class="ttdef"><b>Definition:</b> types.h:212</div></div>
 <div class="ttc" id="group__delivery_html_gaea4522ac1fef9228fb6c743d2a36fd27"><div class="ttname"><a href="group__delivery.html#gaea4522ac1fef9228fb6c743d2a36fd27">pn_dtag</a></div><div class="ttdeci">pn_delivery_tag_t pn_dtag(const char *bytes, size_t size)</div><div class="ttdoc">Construct a delivery tag. </div></div>
 <div class="ttc" id="group__delivery_html_ga5cb4f352dafe1b4866b68f27c37cbeac"><div class="ttname"><a href="group__delivery.html#ga5cb4f352dafe1b4866b68f27c37cbeac">pn_work_head</a></div><div class="ttdeci">pn_delivery_t * pn_work_head(pn_connection_t *connection)</div><div class="ttdoc">Extracts the first delivery on the connection that has pending operations. </div></div>
 <div class="ttc" id="group__delivery_html_ga17523835dbc8d1906bd71df69d09cc40"><div class="ttname"><a href="group__delivery.html#ga17523835dbc8d1906bd71df69d09cc40">pn_delivery_pending</a></div><div class="ttdeci">size_t pn_delivery_pending(pn_delivery_t *delivery)</div><div class="ttdoc">Get the amount of pending message data for a delivery. </div></div>

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/deprecated.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/deprecated.html b/content/releases/qpid-proton-master/proton/c/api/deprecated.html
index 0663a74..dd9a103 100755
--- a/content/releases/qpid-proton-master/proton/c/api/deprecated.html
+++ b/content/releases/qpid-proton-master/proton/c/api/deprecated.html
@@ -94,46 +94,16 @@ $(document).ready(function(){initNavTree('deprecated.html','');});
 </div><!--header-->
 <div class="contents">
 <div class="textblock"><dl class="reflist">
-<dt><a class="anchor" id="_deprecated000018"></a>Module <a class="el" href="group__messenger.html">messenger</a>  </dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000009"></a>File <a class="el" href="messenger_8h.html">messenger.h</a>  </dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000001"></a>Member <a class="el" href="group__connection.html#gad3aad758ccb4690e78d40c1a73567d73">pn_connection_error</a>  (pn_connection_t *connection)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000002"></a>Member <a class="el" href="group__connection.html#ga50613e6c09186dc3f1a2f36238c61f07">pn_connection_get_context</a>  (pn_connection_t *connection)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000003"></a>Member <a class="el" href="group__connection.html#gad3203b366cb1ff5becd1778a8dd6b1a6">pn_connection_set_context</a>  (pn_connection_t *connection, void *context)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000004"></a>Member <a class="el" href="group__delivery.html#ga17c16f34252597f9e737efae1e2ebb81">pn_delivery_get_context</a>  (pn_delivery_t *delivery)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000005"></a>Member <a class="el" href="group__delivery.html#ga91519d3e4568ee8b622d3653e20f60a6">pn_delivery_set_context</a>  (pn_delivery_t *delivery, void *context)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000008"></a>Member <a class="el" href="group__link.html#gaf6f11d778aa4622d8aa5db8962bb1f0a">pn_link_error</a>  (pn_link_t *link)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000006"></a>Member <a class="el" href="group__link.html#ga93e6b527743f433da2ff367c1b2c500a">pn_link_get_context</a>  (pn_link_t *link)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000007"></a>Member <a class="el" href="group__link.html#ga376f2cc18bbd771d95aa8222586d19b2">pn_link_set_context</a>  (pn_link_t *link, void *context)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000012"></a>Member <a class="el" href="group__session.html#ga1685531ca6fb6fb1058d5455a3c3edde">pn_session_error</a>  (pn_session_t *session)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000010"></a>Member <a class="el" href="group__session.html#ga07da6cda67bdb37511b0aa9c8a04d532">pn_session_get_context</a>  (pn_session_t *session)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000011"></a>Member <a class="el" href="group__session.html#ga31f2e4cc76135f79e96453aa72d441b2">pn_session_set_context</a>  (pn_session_t *session, void *context)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000013"></a>Member <a class="el" href="group__transport.html#gaede0bc2a0038ccdc7e1b193e322147fa">pn_transport_error</a>  (pn_transport_t *transport)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000014"></a>Member <a class="el" href="group__transport.html#ga000b2b9ab82139defb1a103f220ec58e">pn_transport_get_context</a>  (pn_transport_t *transport)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000016"></a>Member <a class="el" href="group__transport.html#ga93f5efd9d63ebd1b1498fdace388ec3d">pn_transport_input</a>  (pn_transport_t *transport, const char *bytes, size_t available)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000017"></a>Member <a class="el" href="group__transport.html#gae72fdee3b8aae3cb484b0ed98c2b802e">pn_transport_output</a>  (pn_transport_t *transport, char *bytes, size_t size)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000015"></a>Member <a class="el" href="group__transport.html#gac22041ff85d1a1f5287ac2ba826edb74">pn_transport_set_context</a>  (pn_transport_t *transport, void *context)</dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000019"></a>Module <a class="el" href="group__url.html">url</a>  </dt>
-<dd></dd>
-<dt><a class="anchor" id="_deprecated000020"></a>File <a class="el" href="url_8h.html">url.h</a>  </dt>
-<dd></dd>
+<dt><a class="anchor" id="_deprecated000001"></a>Member <a class="el" href="group__listener.html#ga8a100386ab4a079ae6924aeaafc72eb9">pn_listener_accept</a>  (pn_listener_t *listener, pn_connection_t *connection)</dt>
+<dd>Use pn_listener_accept2(listener, connection, NULL)  </dd>
+<dt><a class="anchor" id="_deprecated000004"></a>Member <a class="el" href="group__proactor.html#ga955471a53dd486a6f227d8d57322a44c">pn_netaddr_listening</a>  (pn_listener_t *l)</dt>
+<dd>Use <a class="el" href="group__proactor.html#gacdbda4ea3dc040af5a4c1d633ddd7cd9" title="Get the listening addresses of a listener. ">pn_listener_addr()</a>  </dd>
+<dt><a class="anchor" id="_deprecated000002"></a>Member <a class="el" href="group__proactor.html#ga7edab5e295c55e1c2169e39aaa082f8b">pn_netaddr_local</a>  (pn_transport_t *t)</dt>
+<dd>Use pn_transport_local_addr  </dd>
+<dt><a class="anchor" id="_deprecated000003"></a>Member <a class="el" href="group__proactor.html#ga59fa5ba7adc39bc8549645d5d33082c0">pn_netaddr_remote</a>  (pn_transport_t *t)</dt>
+<dd>Use <a class="el" href="group__proactor.html#ga3a6d4bda7cfae2780dbb587443eded39" title="Get the local address of a transport. ">pn_transport_remote_addr()</a>  </dd>
+<dt><a class="anchor" id="_deprecated000005"></a>Member <a class="el" href="group__proactor.html#ga9a9d1c4138226fa87160f4769b87f8e6">pn_proactor_connect</a>  (pn_proactor_t *proactor, pn_connection_t *connection, const char *addr)</dt>
+<dd>Use pn_proactor_connect2(proactor, connection, NULL, addr) </dd>
 </dl>
 </div></div><!-- contents -->
 </div><!-- doc-content -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/c/api/dir_25143d27009f52d175c1d192441a738a.js
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/c/api/dir_25143d27009f52d175c1d192441a738a.js b/content/releases/qpid-proton-master/proton/c/api/dir_25143d27009f52d175c1d192441a738a.js
index 45665d8..a7d1380 100755
--- a/content/releases/qpid-proton-master/proton/c/api/dir_25143d27009f52d175c1d192441a738a.js
+++ b/content/releases/qpid-proton-master/proton/c/api/dir_25143d27009f52d175c1d192441a738a.js
@@ -1,24 +1,34 @@
 var dir_25143d27009f52d175c1d192441a738a =
 [
+    [ "cid.h", "cid_8h_source.html", null ],
     [ "codec.h", "codec_8h.html", "codec_8h" ],
     [ "condition.h", "condition_8h.html", "condition_8h" ],
     [ "connection.h", "connection_8h.html", "connection_8h" ],
     [ "connection_driver.h", "connection__driver_8h.html", "connection__driver_8h" ],
     [ "delivery.h", "delivery_8h.html", "delivery_8h" ],
     [ "disposition.h", "disposition_8h.html", "disposition_8h" ],
+    [ "engine.h", "engine_8h_source.html", null ],
     [ "error.h", "error_8h.html", "error_8h" ],
     [ "event.h", "event_8h.html", "event_8h" ],
+    [ "handlers.h", "handlers_8h_source.html", null ],
+    [ "import_export.h", "import__export_8h_source.html", null ],
     [ "link.h", "link_8h.html", "link_8h" ],
     [ "listener.h", "listener_8h.html", "listener_8h" ],
+    [ "log.h", "log_8h_source.html", null ],
     [ "message.h", "message_8h.html", "message_8h" ],
     [ "messenger.h", "messenger_8h.html", "messenger_8h" ],
     [ "netaddr.h", "netaddr_8h.html", "netaddr_8h" ],
+    [ "object.h", "object_8h_source.html", null ],
     [ "proactor.h", "proactor_8h.html", "proactor_8h" ],
+    [ "reactor.h", "reactor_8h_source.html", null ],
+    [ "sasl-plugin.h", "sasl-plugin_8h_source.html", null ],
     [ "sasl.h", "sasl_8h.html", "sasl_8h" ],
+    [ "selectable.h", "selectable_8h_source.html", null ],
     [ "session.h", "session_8h.html", "session_8h" ],
     [ "ssl.h", "ssl_8h.html", "ssl_8h" ],
     [ "terminus.h", "terminus_8h.html", "terminus_8h" ],
     [ "transport.h", "transport_8h.html", "transport_8h" ],
+    [ "type_compat.h", "type__compat_8h_source.html", null ],
     [ "types.h", "types_8h.html", "types_8h" ],
     [ "url.h", "url_8h.html", "url_8h" ]
 ];
\ 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


[04/51] [abbrv] [partial] qpid-site git commit: QPID-8154: Refresh the proton doc snapshot

Posted by jr...@apache.org.
http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp_source.html
index c723a3c..8bf8686 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/listen__handler_8hpp_source.html
@@ -93,13 +93,10 @@ $(document).ready(function(){initNavTree('listen__handler_8hpp_source.html','');
 <div class="title">listen_handler.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="listen__handler_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTEN_HANDLER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTEN_HANDLER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or mo
 re contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   
 13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See 
 the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>
 &#160;</div><div class="line"><a name="l00030"></a><span class="lineno">   30</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="comment">// XXX Discuss more</span></div><div class="line"><a name="l00037"></a><span class="lineno"><a class="line" href="classproton_1_1listen__handler.html">   37</a></span>&#160;<span class="comment"></span><span class="keyword">class </span><a class="code" href="classproton_1_1listen__handler.html">listen_handler</a> {</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00039"></a><span class="lineno">   39</span>&#160;    <span class="keyword">virtual</span> ~<a class="code" href="classproton_1_1listen__handler.html"
 >listen_handler</a>() {}</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;    <span class="keyword">virtual</span> <a class="code" href="classproton_1_1connection__options.html">connection_options</a> <a class="code" href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">on_accept</a>(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;)= 0;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00051"></a><span class="lineno"><a class="line" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">   51</a></span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> <a class="code" href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">on_error</a>(<a class="code" href="classproton_1_1listener.h
 tml">listener</a>&amp;, <span class="keyword">const</span> std::string&amp;) {}</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno"><a class="line" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">   54</a></span>&#160;    <span class="keyword">virtual</span> <span class="keywordtype">void</span> <a class="code" href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">on_close</a>(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;) {}</div><div class="line"><a name="l00055"></a><span class="lineno">   55</span>&#160;};</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00058"></a><span class="lineno">   58</span>&#160;</div><div class=
 "line"><a name="l00059"></a><span class="lineno">   59</span>&#160;<span class="preprocessor">#endif // PROTON_LISTEN_HANDLER_HPP</span></div><div class="ttc" id="classproton_1_1listener_html"><div class="ttname"><a href="classproton_1_1listener.html">proton::listener</a></div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> listener.hpp:33</div></div>
-<div class="ttc" id="classproton_1_1listen__handler_html_a0936d46edbbecedf7eed44a19677b39b"><div class="ttname"><a href="classproton_1_1listen__handler.html#a0936d46edbbecedf7eed44a19677b39b">proton::listen_handler::on_accept</a></div><div class="ttdeci">virtual connection_options on_accept(listener &amp;)=0</div><div class="ttdoc">Called for each accepted connection. </div></div>
+<a href="listen__handler_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTEN_HANDLER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTEN_HANDLER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7</span>&#160;<span class="comment"> * or mo
 re contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00013"></a><span class="lineno">   
 13</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> * KIND, either express or implied.  See 
 the License for the</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * specific language governing permissions and limitations</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00025"></a><span class="lineno">   25</span>&#160;<span class="preprocessor">#include &quot;<a class="code" href="fwd_8hpp.html">./fwd.hpp</a>&quot;</span></div><div class="line"><a name="l00026"></a><span class="lineno">   26</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></
 div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;<span class="preprocessor">#include &lt;string&gt;</span></div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00032"></a><span class="lineno">   32</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00033"></a><span class="lineno">   33</span>&#160;</div><div class="line"><a name="l00034"></a><span class="lineno">   34</span>&#160;<span class="comment">// XXX Discuss more</span></div><div class="line"><a name="l00039"></a><span class="lineno"><a class="line" href="classproton_1_1listen__handler.html">   39</a></span>&#160;<span class="comment"></span><span class="keyword">class </span>PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1listen__handler.html">liste
 n_handler</a> {</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00041"></a><span class="lineno">   41</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> ~<a class="code" href="classproton_1_1listen__handler.html">listen_handler</a>();</div><div class="line"><a name="l00042"></a><span class="lineno">   42</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_open(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;);</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <a class="code" href="classproton_1_1connection__options.html">connection_opt
 ions</a> on_accept(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;);</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;</div><div class="line"><a name="l00056"></a><span class="lineno">   56</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_error(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;, <span class="keyword">const</span> std::string&amp;);</div><div class="line"><a name="l00057"></a><span class="lineno">   57</span>&#160;</div><div class="line"><a name="l00059"></a><span class="lineno">   59</span>&#160;    PN_CPP_EXTERN <span class="keyword">virtual</span> <span class="keywordtype">void</span> on_close(<a class="code" href="classproton_1_1listener.html">listener</a>&amp;);</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;};</div><div class="line"><a name="l00061"></a><span class="lineno">   61</span>&#160;</
 div><div class="line"><a name="l00062"></a><span class="lineno">   62</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00063"></a><span class="lineno">   63</span>&#160;</div><div class="line"><a name="l00064"></a><span class="lineno">   64</span>&#160;<span class="preprocessor">#endif // PROTON_LISTEN_HANDLER_HPP</span></div><div class="ttc" id="classproton_1_1listener_html"><div class="ttname"><a href="classproton_1_1listener.html">proton::listener</a></div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> listener.hpp:33</div></div>
 <div class="ttc" id="fwd_8hpp_html"><div class="ttname"><a href="fwd_8hpp.html">fwd.hpp</a></div><div class="ttdoc">Forward declarations. </div></div>
-<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:65</div></div>
-<div class="ttc" id="classproton_1_1listen__handler_html"><div class="ttname"><a href="classproton_1_1listen__handler.html">proton::listen_handler</a></div><div class="ttdoc">Unsettled API - A handler for incoming connections. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:37</div></div>
-<div class="ttc" id="classproton_1_1listen__handler_html_af30c2c3ffe8921962a164abb1b2a398e"><div class="ttname"><a href="classproton_1_1listen__handler.html#af30c2c3ffe8921962a164abb1b2a398e">proton::listen_handler::on_close</a></div><div class="ttdeci">virtual void on_close(listener &amp;)</div><div class="ttdoc">Called when this listen_handler is no longer needed, and can be deleted. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:54</div></div>
-<div class="ttc" id="classproton_1_1listen__handler_html_a0969610957fd465626cfad89db38ef53"><div class="ttname"><a href="classproton_1_1listen__handler.html#a0969610957fd465626cfad89db38ef53">proton::listen_handler::on_error</a></div><div class="ttdeci">virtual void on_error(listener &amp;, const std::string &amp;)</div><div class="ttdoc">Called if there is a listening error, with an error message. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:51</div></div>
+<div class="ttc" id="classproton_1_1connection__options_html"><div class="ttname"><a href="classproton_1_1connection__options.html">proton::connection_options</a></div><div class="ttdoc">Options for creating a connection. </div><div class="ttdef"><b>Definition:</b> connection_options.hpp:66</div></div>
+<div class="ttc" id="classproton_1_1listen__handler_html"><div class="ttname"><a href="classproton_1_1listen__handler.html">proton::listen_handler</a></div><div class="ttdoc">Unsettled API - A handler for incoming connections. </div><div class="ttdef"><b>Definition:</b> listen_handler.hpp:39</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 </div><!-- fragment --></div><!-- contents -->
 </div><!-- doc-content -->

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/701caf21/content/releases/qpid-proton-master/proton/cpp/api/listener_8hpp_source.html
----------------------------------------------------------------------
diff --git a/content/releases/qpid-proton-master/proton/cpp/api/listener_8hpp_source.html b/content/releases/qpid-proton-master/proton/cpp/api/listener_8hpp_source.html
index bf7b96c..f83883f 100755
--- a/content/releases/qpid-proton-master/proton/cpp/api/listener_8hpp_source.html
+++ b/content/releases/qpid-proton-master/proton/cpp/api/listener_8hpp_source.html
@@ -93,7 +93,7 @@ $(document).ready(function(){initNavTree('listener_8hpp_source.html','');});
 <div class="title">listener.hpp</div>  </div>
 </div><!--header-->
 <div class="contents">
-<a href="listener_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTENER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTENER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7<
 /span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> *
  specific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">struct </span>pn_listener_t;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span cla
 ss="lineno">   30</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno"><a class="line" href="classproton_1_1listener.html">   33</a></span>&#160;<span class="keyword">class </span>PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;    <a class="code" href="classproton_1_1listener.html">listener</a>(pn_listener_t*);</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;    PN_CPP_EXTERN listener();</div><div class="line"><a name="l00041
 "></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop();</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00047"></a><span class="lineno">   47</span>&#160;    pn_listener_t* listener_;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>;</div><div class="line"><a name="l00050"></a><span class="lineno">   50</span>&#160;};</div><div class="line"><a name="l00051"></a><span class="lineno">   51</span>&#160;</div><
 div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;</div><div class="line"><a name="l00054"></a><span class="lineno">   54</span>&#160;<span class="preprocessor">#endif // PROTON_LISTENER_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:55</div></div>
+<a href="listener_8hpp.html">Go to the documentation of this file.</a><div class="fragment"><div class="line"><a name="l00001"></a><span class="lineno">    1</span>&#160;<span class="preprocessor">#ifndef PROTON_LISTENER_HPP</span></div><div class="line"><a name="l00002"></a><span class="lineno">    2</span>&#160;<span class="preprocessor">#define PROTON_LISTENER_HPP</span></div><div class="line"><a name="l00003"></a><span class="lineno">    3</span>&#160;</div><div class="line"><a name="l00004"></a><span class="lineno">    4</span>&#160;<span class="comment">/*</span></div><div class="line"><a name="l00005"></a><span class="lineno">    5</span>&#160;<span class="comment"> * Licensed to the Apache Software Foundation (ASF) under one</span></div><div class="line"><a name="l00006"></a><span class="lineno">    6</span>&#160;<span class="comment"> * or more contributor license agreements.  See the NOTICE file</span></div><div class="line"><a name="l00007"></a><span class="lineno">    7<
 /span>&#160;<span class="comment"> * distributed with this work for additional information</span></div><div class="line"><a name="l00008"></a><span class="lineno">    8</span>&#160;<span class="comment"> * regarding copyright ownership.  The ASF licenses this file</span></div><div class="line"><a name="l00009"></a><span class="lineno">    9</span>&#160;<span class="comment"> * to you under the Apache License, Version 2.0 (the</span></div><div class="line"><a name="l00010"></a><span class="lineno">   10</span>&#160;<span class="comment"> * &quot;License&quot;); you may not use this file except in compliance</span></div><div class="line"><a name="l00011"></a><span class="lineno">   11</span>&#160;<span class="comment"> * with the License.  You may obtain a copy of the License at</span></div><div class="line"><a name="l00012"></a><span class="lineno">   12</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00013"></a><span class="lineno">   13</span>&#160;<spa
 n class="comment"> *   http://www.apache.org/licenses/LICENSE-2.0</span></div><div class="line"><a name="l00014"></a><span class="lineno">   14</span>&#160;<span class="comment"> *</span></div><div class="line"><a name="l00015"></a><span class="lineno">   15</span>&#160;<span class="comment"> * Unless required by applicable law or agreed to in writing,</span></div><div class="line"><a name="l00016"></a><span class="lineno">   16</span>&#160;<span class="comment"> * software distributed under the License is distributed on an</span></div><div class="line"><a name="l00017"></a><span class="lineno">   17</span>&#160;<span class="comment"> * &quot;AS IS&quot; BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY</span></div><div class="line"><a name="l00018"></a><span class="lineno">   18</span>&#160;<span class="comment"> * KIND, either express or implied.  See the License for the</span></div><div class="line"><a name="l00019"></a><span class="lineno">   19</span>&#160;<span class="comment"> *
  specific language governing permissions and limitations</span></div><div class="line"><a name="l00020"></a><span class="lineno">   20</span>&#160;<span class="comment"> * under the License.</span></div><div class="line"><a name="l00021"></a><span class="lineno">   21</span>&#160;<span class="comment"> */</span></div><div class="line"><a name="l00022"></a><span class="lineno">   22</span>&#160;</div><div class="line"><a name="l00023"></a><span class="lineno">   23</span>&#160;<span class="preprocessor">#include &quot;./internal/export.hpp&quot;</span></div><div class="line"><a name="l00024"></a><span class="lineno">   24</span>&#160;</div><div class="line"><a name="l00027"></a><span class="lineno">   27</span>&#160;</div><div class="line"><a name="l00028"></a><span class="lineno">   28</span>&#160;<span class="keyword">struct </span>pn_listener_t;</div><div class="line"><a name="l00029"></a><span class="lineno">   29</span>&#160;</div><div class="line"><a name="l00030"></a><span cla
 ss="lineno">   30</span>&#160;<span class="keyword">namespace </span><a class="code" href="namespaceproton.html">proton</a> {</div><div class="line"><a name="l00031"></a><span class="lineno">   31</span>&#160;</div><div class="line"><a name="l00033"></a><span class="lineno"><a class="line" href="classproton_1_1listener.html">   33</a></span>&#160;<span class="keyword">class </span>PN_CPP_CLASS_EXTERN <a class="code" href="classproton_1_1listener.html">listener</a> {</div><div class="line"><a name="l00035"></a><span class="lineno">   35</span>&#160;    <a class="code" href="classproton_1_1listener.html">listener</a>(pn_listener_t*);</div><div class="line"><a name="l00037"></a><span class="lineno">   37</span>&#160;</div><div class="line"><a name="l00038"></a><span class="lineno">   38</span>&#160;  <span class="keyword">public</span>:</div><div class="line"><a name="l00040"></a><span class="lineno">   40</span>&#160;    PN_CPP_EXTERN listener();</div><div class="line"><a name="l00041
 "></a><span class="lineno">   41</span>&#160;</div><div class="line"><a name="l00043"></a><span class="lineno">   43</span>&#160;    PN_CPP_EXTERN listener(<span class="keyword">const</span> listener&amp;);</div><div class="line"><a name="l00044"></a><span class="lineno">   44</span>&#160;</div><div class="line"><a name="l00045"></a><span class="lineno">   45</span>&#160;    PN_CPP_EXTERN ~listener();</div><div class="line"><a name="l00046"></a><span class="lineno">   46</span>&#160;</div><div class="line"><a name="l00048"></a><span class="lineno">   48</span>&#160;    PN_CPP_EXTERN listener&amp; operator=(<span class="keyword">const</span> listener&amp;);</div><div class="line"><a name="l00049"></a><span class="lineno">   49</span>&#160;</div><div class="line"><a name="l00052"></a><span class="lineno">   52</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">void</span> stop();</div><div class="line"><a name="l00053"></a><span class="lineno">   53</span>&#160;</div><div class="
 line"><a name="l00059"></a><span class="lineno">   59</span>&#160;    PN_CPP_EXTERN <span class="keywordtype">int</span> port();</div><div class="line"><a name="l00060"></a><span class="lineno">   60</span>&#160;</div><div class="line"><a name="l00065"></a><span class="lineno">   65</span>&#160;    PN_CPP_EXTERN <span class="keyword">class </span><a class="code" href="classproton_1_1container.html">container</a>&amp; <a class="code" href="classproton_1_1container.html">container</a>() <span class="keyword">const</span>;</div><div class="line"><a name="l00066"></a><span class="lineno">   66</span>&#160;</div><div class="line"><a name="l00067"></a><span class="lineno">   67</span>&#160;  <span class="keyword">private</span>:</div><div class="line"><a name="l00068"></a><span class="lineno">   68</span>&#160;    pn_listener_t* listener_;</div><div class="line"><a name="l00069"></a><span class="lineno">   69</span>&#160;</div><div class="line"><a name="l00070"></a><span class="lineno">  
  70</span>&#160;  <span class="keyword">friend</span> <span class="keyword">class </span>container;</div><div class="line"><a name="l00071"></a><span class="lineno">   71</span>&#160;};</div><div class="line"><a name="l00072"></a><span class="lineno">   72</span>&#160;</div><div class="line"><a name="l00073"></a><span class="lineno">   73</span>&#160;} <span class="comment">// proton</span></div><div class="line"><a name="l00074"></a><span class="lineno">   74</span>&#160;</div><div class="line"><a name="l00075"></a><span class="lineno">   75</span>&#160;<span class="preprocessor">#endif // PROTON_LISTENER_HPP</span></div><div class="ttc" id="classproton_1_1container_html"><div class="ttname"><a href="classproton_1_1container.html">proton::container</a></div><div class="ttdoc">A top-level container of connections, sessions, and links. </div><div class="ttdef"><b>Definition:</b> container.hpp:50</div></div>
 <div class="ttc" id="classproton_1_1listener_html"><div class="ttname"><a href="classproton_1_1listener.html">proton::listener</a></div><div class="ttdoc">A listener for incoming connections. </div><div class="ttdef"><b>Definition:</b> listener.hpp:33</div></div>
 <div class="ttc" id="namespaceproton_html"><div class="ttname"><a href="namespaceproton.html">proton</a></div><div class="ttdoc">The main Proton namespace. </div><div class="ttdef"><b>Definition:</b> annotation_key.hpp:33</div></div>
 </div><!-- fragment --></div><!-- contents -->


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