You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by as...@apache.org on 2016/05/17 20:53:19 UTC

[2/3] qpid-proton git commit: PROTON-1203: Change header files include usage: - In exported headers always use #include "" and relative paths to other proton-cpp include files - In exported headers always use #include <> for proton-c includes - Only use

PROTON-1203: Change header files include usage:
- In exported headers always use #include "" and relative paths to other proton-cpp include files
- In exported headers always use #include <> for proton-c includes
- Only use #include "" for proton cpp files from within cpp implementation
- Always use #include <> for proton-c header files within cpp implementation
- Make all examples use #include <> for proton cpp includes
- Move the exported header files config.hpp and export.hpp to internal
- Don't include config.hpp directly in examples as it is an internal header file
- Reinstate a more compatible version of fake_cpp11.hpp


Project: http://git-wip-us.apache.org/repos/asf/qpid-proton/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-proton/commit/1a9470a2
Tree: http://git-wip-us.apache.org/repos/asf/qpid-proton/tree/1a9470a2
Diff: http://git-wip-us.apache.org/repos/asf/qpid-proton/diff/1a9470a2

Branch: refs/heads/master
Commit: 1a9470a2783e157986a50d1dded1e91f6bac87d3
Parents: 631255c
Author: Andrew Stitcher <as...@apache.org>
Authored: Tue May 17 15:47:20 2016 -0400
Committer: Andrew Stitcher <as...@apache.org>
Committed: Tue May 17 16:42:21 2016 -0400

----------------------------------------------------------------------
 examples/cpp/broker.cpp                         | 47 +++++------
 examples/cpp/broker.hpp                         | 46 +++++------
 examples/cpp/client.cpp                         | 20 ++---
 examples/cpp/connection_options.cpp             | 18 ++---
 examples/cpp/direct_recv.cpp                    | 18 ++---
 examples/cpp/direct_send.cpp                    | 20 ++---
 examples/cpp/fake_cpp11.hpp                     | 34 ++++++++
 examples/cpp/flow_control.cpp                   | 34 ++++----
 examples/cpp/helloworld.cpp                     | 22 ++---
 examples/cpp/helloworld_direct.cpp              | 22 ++---
 examples/cpp/mt/broker.cpp                      | 22 ++---
 examples/cpp/mt/epoll_container.cpp             | 20 ++---
 examples/cpp/queue_browser.cpp                  | 20 ++---
 examples/cpp/selected_recv.cpp                  | 18 ++---
 examples/cpp/server.cpp                         | 16 ++--
 examples/cpp/server_direct.cpp                  | 18 ++---
 examples/cpp/simple_recv.cpp                    | 20 ++---
 examples/cpp/simple_send.cpp                    | 20 ++---
 examples/cpp/ssl.cpp                            | 28 +++----
 examples/cpp/ssl_client_cert.cpp                | 30 +++----
 .../cpp/include/proton/annotation_key.hpp       |  4 +-
 proton-c/bindings/cpp/include/proton/binary.hpp |  4 +-
 .../bindings/cpp/include/proton/byte_array.hpp  |  6 +-
 .../bindings/cpp/include/proton/codec/data.hpp  |  6 +-
 .../cpp/include/proton/codec/decoder.hpp        |  6 +-
 .../bindings/cpp/include/proton/codec/deque.hpp |  4 +-
 .../cpp/include/proton/codec/encoder.hpp        |  6 +-
 .../cpp/include/proton/codec/forward_list.hpp   |  4 +-
 .../bindings/cpp/include/proton/codec/list.hpp  |  4 +-
 .../bindings/cpp/include/proton/codec/map.hpp   |  4 +-
 .../cpp/include/proton/codec/unordered_map.hpp  |  4 +-
 .../cpp/include/proton/codec/vector.hpp         |  4 +-
 proton-c/bindings/cpp/include/proton/config.hpp | 84 --------------------
 .../bindings/cpp/include/proton/connection.hpp  | 10 +--
 .../cpp/include/proton/connection_options.hpp   | 12 +--
 .../bindings/cpp/include/proton/container.hpp   | 10 +--
 .../bindings/cpp/include/proton/decimal.hpp     |  8 +-
 .../cpp/include/proton/default_container.hpp    |  2 +-
 .../bindings/cpp/include/proton/delivery.hpp    | 10 +--
 .../bindings/cpp/include/proton/duration.hpp    |  6 +-
 .../bindings/cpp/include/proton/endpoint.hpp    |  8 +-
 proton-c/bindings/cpp/include/proton/error.hpp  |  6 +-
 .../cpp/include/proton/error_condition.hpp      |  6 +-
 .../bindings/cpp/include/proton/event_loop.hpp  |  2 +-
 proton-c/bindings/cpp/include/proton/export.hpp | 57 -------------
 .../cpp/include/proton/internal/config.hpp      | 84 ++++++++++++++++++++
 .../cpp/include/proton/internal/export.hpp      | 57 +++++++++++++
 .../cpp/include/proton/internal/object.hpp      |  6 +-
 .../include/proton/internal/pn_unique_ptr.hpp   |  2 +-
 .../cpp/include/proton/internal/scalar_base.hpp | 22 ++---
 .../cpp/include/proton/internal/type_traits.hpp |  6 +-
 .../cpp/include/proton/io/connection_engine.hpp | 18 ++---
 .../include/proton/io/container_impl_base.hpp   |  4 +-
 proton-c/bindings/cpp/include/proton/link.hpp   | 20 ++---
 .../bindings/cpp/include/proton/listener.hpp    |  2 +-
 .../bindings/cpp/include/proton/message.hpp     | 14 ++--
 .../bindings/cpp/include/proton/message_id.hpp  |  6 +-
 .../cpp/include/proton/messaging_handler.hpp    |  4 +-
 .../bindings/cpp/include/proton/receiver.hpp    |  9 ++-
 .../cpp/include/proton/receiver_options.hpp     | 12 +--
 .../cpp/include/proton/reconnect_timer.hpp      |  8 +-
 proton-c/bindings/cpp/include/proton/sasl.hpp   |  8 +-
 proton-c/bindings/cpp/include/proton/scalar.hpp |  2 +-
 proton-c/bindings/cpp/include/proton/sender.hpp | 10 +--
 .../cpp/include/proton/sender_options.hpp       | 12 +--
 .../bindings/cpp/include/proton/session.hpp     | 16 ++--
 .../cpp/include/proton/session_options.hpp      |  8 +-
 proton-c/bindings/cpp/include/proton/source.hpp | 10 +--
 .../cpp/include/proton/source_options.hpp       | 12 +--
 proton-c/bindings/cpp/include/proton/ssl.hpp    |  6 +-
 proton-c/bindings/cpp/include/proton/target.hpp |  8 +-
 .../cpp/include/proton/target_options.hpp       | 14 ++--
 proton-c/bindings/cpp/include/proton/task.hpp   |  6 +-
 .../bindings/cpp/include/proton/terminus.hpp    |  8 +-
 .../bindings/cpp/include/proton/thread_safe.hpp | 10 +--
 .../bindings/cpp/include/proton/timestamp.hpp   |  2 +-
 .../bindings/cpp/include/proton/tracker.hpp     |  4 +-
 .../bindings/cpp/include/proton/transfer.hpp    |  8 +-
 .../bindings/cpp/include/proton/transport.hpp   |  6 +-
 .../bindings/cpp/include/proton/type_id.hpp     |  4 +-
 proton-c/bindings/cpp/include/proton/types.hpp  | 38 ++++-----
 .../bindings/cpp/include/proton/types_fwd.hpp   |  4 +-
 proton-c/bindings/cpp/include/proton/url.hpp    |  4 +-
 proton-c/bindings/cpp/include/proton/uuid.hpp   |  4 +-
 proton-c/bindings/cpp/include/proton/value.hpp  |  8 +-
 proton-c/bindings/cpp/src/acceptor.hpp          |  4 +-
 proton-c/bindings/cpp/src/binary.cpp            |  2 +-
 proton-c/bindings/cpp/src/byte_array.cpp        |  2 +-
 proton-c/bindings/cpp/src/codec_test.cpp        |  6 +-
 proton-c/bindings/cpp/src/connection.cpp        | 10 +--
 .../bindings/cpp/src/connection_options.cpp     |  4 +-
 proton-c/bindings/cpp/src/connector.cpp         |  4 +-
 proton-c/bindings/cpp/src/connector.hpp         |  4 +-
 proton-c/bindings/cpp/src/container.cpp         |  4 +-
 proton-c/bindings/cpp/src/container_impl.cpp    |  8 +-
 proton-c/bindings/cpp/src/container_impl.hpp    |  3 +-
 proton-c/bindings/cpp/src/contexts.cpp          | 12 +--
 proton-c/bindings/cpp/src/data.cpp              | 16 ++--
 proton-c/bindings/cpp/src/decoder.cpp           | 20 ++---
 proton-c/bindings/cpp/src/encoder.cpp           | 20 ++---
 proton-c/bindings/cpp/src/endpoint.cpp          |  6 +-
 proton-c/bindings/cpp/src/engine_test.cpp       | 14 ++--
 proton-c/bindings/cpp/src/error_condition.cpp   |  2 +-
 proton-c/bindings/cpp/src/event_loop.cpp        |  2 +-
 proton-c/bindings/cpp/src/handler.cpp           |  2 +-
 proton-c/bindings/cpp/src/link.cpp              |  6 +-
 proton-c/bindings/cpp/src/message.cpp           |  2 +-
 proton-c/bindings/cpp/src/messaging_adapter.cpp | 14 ++--
 proton-c/bindings/cpp/src/messaging_adapter.hpp |  4 +-
 proton-c/bindings/cpp/src/proton_event.hpp      |  2 +-
 proton-c/bindings/cpp/src/proton_handler.hpp    |  1 -
 proton-c/bindings/cpp/src/receiver.cpp          | 10 +--
 proton-c/bindings/cpp/src/receiver_options.cpp  |  2 +-
 proton-c/bindings/cpp/src/reconnect_timer.cpp   |  4 +-
 proton-c/bindings/cpp/src/scalar_test.cpp       | 10 +--
 proton-c/bindings/cpp/src/sender.cpp            |  6 +-
 proton-c/bindings/cpp/src/session.cpp           |  4 +-
 proton-c/bindings/cpp/src/session_options.cpp   |  2 +-
 proton-c/bindings/cpp/src/ssl.cpp               |  2 +-
 proton-c/bindings/cpp/src/ssl_domain.cpp        |  2 +-
 proton-c/bindings/cpp/src/task.cpp              |  2 +-
 proton-c/bindings/cpp/src/terminus.cpp          |  2 +-
 proton-c/bindings/cpp/src/test_bits.hpp         |  2 +-
 proton-c/bindings/cpp/src/timestamp.cpp         |  2 +-
 proton-c/bindings/cpp/src/transfer.cpp          |  6 +-
 proton-c/bindings/cpp/src/transport.cpp         |  4 +-
 proton-c/bindings/cpp/src/type_id.cpp           |  2 +-
 proton-c/bindings/cpp/src/types_internal.hpp    |  6 +-
 proton-c/bindings/cpp/src/url.cpp               |  2 +-
 proton-c/bindings/cpp/src/uuid.cpp              |  4 +-
 proton-c/bindings/cpp/src/value_test.cpp        |  4 +-
 131 files changed, 773 insertions(+), 735 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/broker.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/broker.cpp b/examples/cpp/broker.cpp
index 87d9949..bb3aefb 100644
--- a/examples/cpp/broker.cpp
+++ b/examples/cpp/broker.cpp
@@ -19,21 +19,20 @@
  *
  */
 
-#include "proton/config.hpp"
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/message.hpp"
-#include "proton/receiver_options.hpp"
-#include "proton/sender.hpp"
-#include "proton/sender_options.hpp"
-#include "proton/source_options.hpp"
-#include "proton/target_options.hpp"
-#include "proton/transport.hpp"
-#include "proton/url.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/message.hpp>
+#include <proton/receiver_options.hpp>
+#include <proton/sender.hpp>
+#include <proton/sender_options.hpp>
+#include <proton/source_options.hpp>
+#include <proton/target_options.hpp>
+#include <proton/transport.hpp>
+#include <proton/url.hpp>
 
 #include <deque>
 #include <iostream>
@@ -41,6 +40,8 @@
 #include <map>
 #include <string>
 
+#include "fake_cpp11.hpp"
+
 /// A simple implementation of a queue.
 class queue {
   public:
@@ -154,7 +155,7 @@ class broker_handler : public proton::messaging_handler {
   public:
     broker_handler(queues& qs) : queues_(qs) {}
 
-    void on_sender_open(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_open(proton::sender &sender) OVERRIDE {
         proton::source src(sender.source());
         queue &q = src.dynamic() ?
             queues_.dynamic() : queues_.get(src.address());
@@ -163,7 +164,7 @@ class broker_handler : public proton::messaging_handler {
         std::cout << "broker outgoing link from " << q.name() << std::endl;
     }
 
-    void on_receiver_open(proton::receiver &receiver) PN_CPP_OVERRIDE {
+    void on_receiver_open(proton::receiver &receiver) OVERRIDE {
         std::string address = receiver.target().address();
         if (!address.empty()) {
             receiver.open(proton::receiver_options().target(proton::target_options().address(address)));
@@ -179,23 +180,23 @@ class broker_handler : public proton::messaging_handler {
         }
     }
 
-    void on_sender_close(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_close(proton::sender &sender) OVERRIDE {
         unsubscribe(sender);
     }
 
-    void on_connection_close(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_close(proton::connection &c) OVERRIDE {
         remove_stale_consumers(c);
     }
 
-    void on_transport_close(proton::transport &t) PN_CPP_OVERRIDE {
+    void on_transport_close(proton::transport &t) OVERRIDE {
         remove_stale_consumers(t.connection());
     }
 
-    void on_transport_error(proton::transport &t) PN_CPP_OVERRIDE {
+    void on_transport_error(proton::transport &t) OVERRIDE {
         std::cout << "broker client disconnect: " << t.error().what() << std::endl;
     }
 
-    void on_error(const proton::error_condition &c) PN_CPP_OVERRIDE {
+    void on_error(const proton::error_condition &c) OVERRIDE {
         std::cerr << "broker error: " << c.what() << std::endl;
     }
 
@@ -210,13 +211,13 @@ class broker_handler : public proton::messaging_handler {
         }
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         std::string address = s.source().address();
 
         queues_.get(address).dispatch(&s);
     }
 
-    void on_message(proton::delivery &d, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &m) OVERRIDE {
         std::string address = d.receiver().target().address();
         queues_.get(address).publish(m);
     }
@@ -238,7 +239,7 @@ class broker {
       public:
         my_handler(const std::string& u, queues& qs) : broker_handler(qs), url_(u) {}
 
-        void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+        void on_container_start(proton::container &c) OVERRIDE {
             c.listen(url_);
             std::cout << "broker listening on " << url_ << std::endl;
         }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/broker.hpp
----------------------------------------------------------------------
diff --git a/examples/cpp/broker.hpp b/examples/cpp/broker.hpp
index c8e4ae2..184ddc7 100644
--- a/examples/cpp/broker.hpp
+++ b/examples/cpp/broker.hpp
@@ -27,18 +27,18 @@
 /// The examples add functionality as needed, this helps to make it
 /// easier to see the important differences between the examples.
 
-#include "proton/connection.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/message.hpp"
-#include "proton/sasl.hpp"
-#include "proton/sender.hpp"
-#include "proton/tracker.hpp"
-#include "proton/transport.hpp"
-#include "proton/sender_options.hpp"
-#include "proton/receiver_options.hpp"
-#include "proton/source_options.hpp"
-#include "proton/target_options.hpp"
+#include <proton/connection.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/message.hpp>
+#include <proton/sasl.hpp>
+#include <proton/sender.hpp>
+#include <proton/tracker.hpp>
+#include <proton/transport.hpp>
+#include <proton/sender_options.hpp>
+#include <proton/receiver_options.hpp>
+#include <proton/source_options.hpp>
+#include <proton/target_options.hpp>
 
 #include <iostream>
 #include <deque>
@@ -154,18 +154,18 @@ class queues {
     uint64_t next_id_; // Use to generate unique queue IDs.
 };
 
-#include "proton/config.hpp"
+#include <proton/config.hpp>
 
 /** Common handler logic for brokers. */
 class broker_handler : public proton::messaging_handler {
   public:
     broker_handler(queues& qs) : queues_(qs) {}
 
-    void on_transport_open(proton::transport &t) PN_CPP_OVERRIDE {
+    void on_transport_open(proton::transport &t) OVERRIDE {
         std::cout << "Connection from user: " << t.sasl().user() << " (mechanism: " << t.sasl().mech() << ")" << std::endl;
     }
 
-    void on_sender_open(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_open(proton::sender &sender) OVERRIDE {
         proton::source src(sender.source());
         queue &q = src.dynamic() ?
             queues_.dynamic() : queues_.get(src.address());
@@ -174,7 +174,7 @@ class broker_handler : public proton::messaging_handler {
         std::cout << "broker outgoing link from " << q.name() << std::endl;
     }
 
-    void on_receiver_open(proton::receiver &receiver) PN_CPP_OVERRIDE {
+    void on_receiver_open(proton::receiver &receiver) OVERRIDE {
         std::string address = receiver.target().address();
         if (!address.empty()) {
             receiver.open(proton::receiver_options().target(proton::target_options().address(address)));
@@ -190,23 +190,23 @@ class broker_handler : public proton::messaging_handler {
         }
     }
 
-    void on_sender_close(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_close(proton::sender &sender) OVERRIDE {
         unsubscribe(sender);
     }
 
-    void on_connection_close(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_close(proton::connection &c) OVERRIDE {
         remove_stale_consumers(c);
     }
 
-    void on_transport_close(proton::transport &t) PN_CPP_OVERRIDE {
+    void on_transport_close(proton::transport &t) OVERRIDE {
         remove_stale_consumers(t.connection());
     }
 
-    void on_transport_error(proton::transport &t) PN_CPP_OVERRIDE {
+    void on_transport_error(proton::transport &t) OVERRIDE {
         std::cout << "broker client disconnect: " << t.error().what() << std::endl;
     }
 
-    void on_error(const proton::error_condition &c) PN_CPP_OVERRIDE {
+    void on_error(const proton::error_condition &c) OVERRIDE {
         std::cerr << "broker error: " << c.what() << std::endl;
     }
 
@@ -218,13 +218,13 @@ class broker_handler : public proton::messaging_handler {
         }
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         std::string address = s.source().address();
 
         queues_.get(address).dispatch(&s);
     }
 
-    void on_message(proton::delivery &d, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &m) OVERRIDE {
         std::string address = d.receiver().target().address();
         queues_.get(address).publish(m);
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/client.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/client.cpp b/examples/cpp/client.cpp
index 95a504c..dd22ccd 100644
--- a/examples/cpp/client.cpp
+++ b/examples/cpp/client.cpp
@@ -20,17 +20,17 @@
  */
 
 #include "options.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/connection.hpp"
-#include "proton/tracker.hpp"
-#include "proton/source_options.hpp"
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/connection.hpp>
+#include <proton/tracker.hpp>
+#include <proton/source_options.hpp>
 
 #include <iostream>
 #include <vector>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 using proton::receiver_options;
 using proton::source_options;
@@ -45,7 +45,7 @@ class client : public proton::messaging_handler {
   public:
     client(const std::string &u, const std::vector<std::string>& r) : url(u), requests(r) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         sender = c.open_sender(url);
         // Create a receiver requesting a dynamically created queue
         // for the message source.
@@ -60,11 +60,11 @@ class client : public proton::messaging_handler {
         sender.send(req);
     }
 
-    void on_receiver_open(proton::receiver &) PN_CPP_OVERRIDE {
+    void on_receiver_open(proton::receiver &) OVERRIDE {
         send_request();
     }
 
-    void on_message(proton::delivery &d, proton::message &response) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &response) OVERRIDE {
         if (requests.empty()) return; // Spurious extra message!
 
         std::cout << requests.front() << " => " << response.body() << std::endl;

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/connection_options.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/connection_options.cpp b/examples/cpp/connection_options.cpp
index e615602..f9935a8 100644
--- a/examples/cpp/connection_options.cpp
+++ b/examples/cpp/connection_options.cpp
@@ -19,20 +19,20 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/connection_options.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/transport.hpp"
+#include <proton/connection.hpp>
+#include <proton/connection_options.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/transport.hpp>
 
 #include <iostream>
 
 using proton::connection_options;
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class handler_2 : public proton::messaging_handler {
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::cout << "connection events going to handler_2" << std::endl;
         std::cout << "connection max_frame_size: " << c.max_frame_size() <<
             ", idle timeout: " << c.idle_timeout() << std::endl;
@@ -48,13 +48,13 @@ class main_handler : public proton::messaging_handler {
   public:
     main_handler(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         // Connection options for this connection.  Merged with and overriding the container's
         // client_connection_options() settings.
         c.connect(url, connection_options().handler(conn_handler).max_frame_size(2468));
     }
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::cout << "unexpected connection event on main handler" << std::endl;
         c.close();
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/direct_recv.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/direct_recv.cpp b/examples/cpp/direct_recv.cpp
index 1142c9e..edbc8b6 100644
--- a/examples/cpp/direct_recv.cpp
+++ b/examples/cpp/direct_recv.cpp
@@ -21,17 +21,17 @@
 
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/link.hpp"
-#include "proton/value.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/link.hpp>
+#include <proton/value.hpp>
 
 #include <iostream>
 #include <map>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class direct_recv : public proton::messaging_handler {
   private:
@@ -43,12 +43,12 @@ class direct_recv : public proton::messaging_handler {
   public:
     direct_recv(const std::string &s, int c) : url(s), expected(c), received(0) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         listener = c.listen(url);
         std::cout << "direct_recv listening on " << url << std::endl;
     }
 
-    void on_message(proton::delivery &d, proton::message &msg) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &msg) OVERRIDE {
         if (proton::coerce<uint64_t>(msg.id()) < received) {
             return; // Ignore duplicate
         }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/direct_send.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/direct_send.cpp b/examples/cpp/direct_send.cpp
index 5f3e68a..d8427b7 100644
--- a/examples/cpp/direct_send.cpp
+++ b/examples/cpp/direct_send.cpp
@@ -21,16 +21,16 @@
 
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/value.hpp"
-#include "proton/tracker.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/value.hpp>
+#include <proton/tracker.hpp>
 
 #include <iostream>
 #include <map>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class simple_send : public proton::messaging_handler {
   private:
@@ -43,12 +43,12 @@ class simple_send : public proton::messaging_handler {
   public:
     simple_send(const std::string &s, int c) : url(s), sent(0), confirmed(0), total(c) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         listener = c.listen(url);
         std::cout << "direct_send listening on " << url << std::endl;
     }
 
-    void on_sendable(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &sender) OVERRIDE {
         while (sender.credit() && sent < total) {
             proton::message msg;
             std::map<std::string, int> m;
@@ -62,7 +62,7 @@ class simple_send : public proton::messaging_handler {
         }
     }
 
-    void on_tracker_accept(proton::tracker &t) PN_CPP_OVERRIDE {
+    void on_tracker_accept(proton::tracker &t) OVERRIDE {
         confirmed++;
 
         if (confirmed == total) {
@@ -72,7 +72,7 @@ class simple_send : public proton::messaging_handler {
         }
     }
 
-    void on_transport_close(proton::transport &) PN_CPP_OVERRIDE {
+    void on_transport_close(proton::transport &) OVERRIDE {
         sent = confirmed;
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/fake_cpp11.hpp
----------------------------------------------------------------------
diff --git a/examples/cpp/fake_cpp11.hpp b/examples/cpp/fake_cpp11.hpp
new file mode 100644
index 0000000..03daa3b
--- /dev/null
+++ b/examples/cpp/fake_cpp11.hpp
@@ -0,0 +1,34 @@
+#ifndef FAKE_CPP11_HPP
+#define FAKE_CPP11_HPP
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+/// These definitions allow us to use some new C++11 features in previous compilers
+///
+/// It is strongly recommended not to copy this - just use C++11/C++14 instead!
+
+#if __cplusplus < 201103L
+#define OVERRIDE
+#else
+#define OVERRIDE override
+#endif
+
+
+#endif // FAKE_CPP11_HPP

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/flow_control.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/flow_control.cpp b/examples/cpp/flow_control.cpp
index 8be9777..2eedd65 100644
--- a/examples/cpp/flow_control.cpp
+++ b/examples/cpp/flow_control.cpp
@@ -19,19 +19,19 @@
  *
  */
 
-#include "proton/listener.hpp"
-#include "proton/connection.hpp"
-#include "proton/connection_options.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/sender.hpp"
-#include "proton/tracker.hpp"
-#include "proton/delivery.hpp"
+#include <proton/listener.hpp>
+#include <proton/connection.hpp>
+#include <proton/connection_options.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/sender.hpp>
+#include <proton/tracker.hpp>
+#include <proton/delivery.hpp>
 
 #include <iostream>
 #include <sstream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 namespace {
 
@@ -57,7 +57,7 @@ class flow_sender : public proton::messaging_handler {
   public:
     flow_sender() : available(0), sequence(0) {}
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         if (verbose)
             std::cout << "flow_sender in \"on_sendable\" with credit " << s.credit()
                       << " and " << available << " available messages" << std::endl;
@@ -70,7 +70,7 @@ class flow_sender : public proton::messaging_handler {
         }
     }
 
-    void on_sender_drain_start(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sender_drain_start(proton::sender &s) OVERRIDE {
         if (verbose)
             std::cout << "flow_sender in \"on_drain_start\" with credit " << s.credit()
                       << " making an internal call to \"on_sendble\"" << std::endl;
@@ -165,11 +165,11 @@ class flow_receiver : public proton::messaging_handler {
         stage++;
     }
 
-    void on_receiver_open(proton::receiver &r) PN_CPP_OVERRIDE {
+    void on_receiver_open(proton::receiver &r) OVERRIDE {
         run_stage(r, "on_receiver_open");
     }
 
-    void on_message(proton::delivery &d, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &m) OVERRIDE {
         if (verbose)
             std::cout << "flow_receiver in \"on_message\" with " << m.body() << std::endl;
         proton::receiver r(d.receiver());
@@ -177,7 +177,7 @@ class flow_receiver : public proton::messaging_handler {
         run_stage(r, "on_message");
     }
 
-    void on_receiver_drain_finish(proton::receiver &r) PN_CPP_OVERRIDE {
+    void on_receiver_drain_finish(proton::receiver &r) OVERRIDE {
         if (verbose)
             std::cout << "flow_receiver in \"on_receiver_drain_finish\"" << std::endl;
         run_stage(r, "on_receiver_drain_finish");
@@ -195,19 +195,19 @@ class flow_control : public proton::messaging_handler {
   public:
     flow_control(const std::string& u) : url(u), receive_handler(send_handler) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         listener = c.listen(url, proton::connection_options().handler(send_handler));
         c.connect(url);
     }
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         if (c.active()) {
             // outbound connection
             c.open_receiver("flow_example", proton::receiver_options().handler(receive_handler).credit_window(0));
         }
     }
 
-    void on_connection_close(proton::connection &) PN_CPP_OVERRIDE {
+    void on_connection_close(proton::connection &) OVERRIDE {
         listener.stop();
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/helloworld.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/helloworld.cpp b/examples/cpp/helloworld.cpp
index 4e94713..84a5919 100644
--- a/examples/cpp/helloworld.cpp
+++ b/examples/cpp/helloworld.cpp
@@ -19,16 +19,16 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/tracker.hpp"
-#include "proton/url.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/tracker.hpp>
+#include <proton/url.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class hello_world : public proton::messaging_handler {
   private:
@@ -37,22 +37,22 @@ class hello_world : public proton::messaging_handler {
   public:
     hello_world(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container& c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container& c) OVERRIDE {
         c.connect(url);
     }
 
-    void on_connection_open(proton::connection& c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection& c) OVERRIDE {
         c.open_receiver(url.path());
         c.open_sender(url.path());
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         proton::message m("Hello World!");
         s.send(m);
         s.close();
     }
 
-    void on_message(proton::delivery &d, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
         d.connection().close();
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/helloworld_direct.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/helloworld_direct.cpp b/examples/cpp/helloworld_direct.cpp
index 5f7de40..5421e62 100644
--- a/examples/cpp/helloworld_direct.cpp
+++ b/examples/cpp/helloworld_direct.cpp
@@ -19,15 +19,15 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/sender.hpp"
-#include "proton/tracker.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/sender.hpp>
+#include <proton/tracker.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class hello_world_direct : public proton::messaging_handler {
   private:
@@ -37,26 +37,26 @@ class hello_world_direct : public proton::messaging_handler {
   public:
     hello_world_direct(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         listener = c.listen(url);
         c.open_sender(url);
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         proton::message m("Hello World!");
         s.send(m);
         s.close();
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
     }
 
-    void on_tracker_accept(proton::tracker &t) PN_CPP_OVERRIDE {
+    void on_tracker_accept(proton::tracker &t) OVERRIDE {
         t.connection().close();
     }
 
-    void on_connection_close(proton::connection&) PN_CPP_OVERRIDE {
+    void on_connection_close(proton::connection&) OVERRIDE {
         listener.stop();
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/mt/broker.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/mt/broker.cpp b/examples/cpp/mt/broker.cpp
index 97d7cbf..00ebb55 100644
--- a/examples/cpp/mt/broker.cpp
+++ b/examples/cpp/mt/broker.cpp
@@ -33,6 +33,8 @@
 #include <mutex>
 #include <thread>
 
+#include "../fake_cpp11.hpp"
+
 // Thread safe queue.
 // Stores messages, notifies subscribed connections when there is data.
 class queue {
@@ -125,7 +127,7 @@ class broker_connection_handler : public proton::messaging_handler {
   public:
     broker_connection_handler(queues& qs) : queues_(qs) {}
 
-    void on_connection_open(proton::connection& c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection& c) OVERRIDE {
         // Create the has_messages callback for use with queue subscriptions.
         //
         // FIXME aconway 2016-05-09: doc lifecycle: handler tied to c.
@@ -139,21 +141,21 @@ class broker_connection_handler : public proton::messaging_handler {
     }
 
     // A sender sends messages from a queue to a subscriber.
-    void on_sender_open(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_open(proton::sender &sender) OVERRIDE {
         queue *q = sender.source().dynamic() ?
             queues_.dynamic() : queues_.get(sender.source().address());
         std::cout << "sending from " << q->name() << std::endl;
     }
 
     // We have credit to send a message.
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         queue* q = sender_queue(s);
         if (!do_send(q, s))     // Queue is empty, save ourselves in the blocked set.
             blocked_.insert(std::make_pair(q, s));
     }
 
     // A receiver receives messages from a publisher to a queue.
-    void on_receiver_open(proton::receiver &r) PN_CPP_OVERRIDE {
+    void on_receiver_open(proton::receiver &r) OVERRIDE {
         std::string qname = r.target().address();
         if (qname == "shutdown") {
             std::cout << "broker shutting down" << std::endl;
@@ -166,12 +168,12 @@ class broker_connection_handler : public proton::messaging_handler {
     }
 
     // A message is received.
-    void on_message(proton::delivery &d, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &m) OVERRIDE {
         std::string qname = d.receiver().target().address();
         queues_.get(qname)->push(m);
     }
 
-    void on_session_close(proton::session &session) PN_CPP_OVERRIDE {
+    void on_session_close(proton::session &session) OVERRIDE {
         // Erase all blocked senders that belong to session.
         auto predicate = [session](const proton::sender& s) {
             return s.session() == session;
@@ -179,7 +181,7 @@ class broker_connection_handler : public proton::messaging_handler {
         erase_sender_if(blocked_.begin(), blocked_.end(), predicate);
     }
 
-    void on_sender_close(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_close(proton::sender &sender) OVERRIDE {
         // Erase sender from the blocked set.
         auto range = blocked_.equal_range(sender_queue(sender));
         auto predicate = [sender](const proton::sender& s) { return s == sender; };
@@ -187,7 +189,7 @@ class broker_connection_handler : public proton::messaging_handler {
     }
 
     // The container calls on_transport_close() last.
-    void on_transport_close(proton::transport&) PN_CPP_OVERRIDE {
+    void on_transport_close(proton::transport&) OVERRIDE {
         delete this;            // All done.
     }
 
@@ -262,11 +264,11 @@ class broker {
     struct listener : public proton::listen_handler {
         listener(queues& qs) : queues_(qs) {}
 
-        proton::connection_options on_accept() PN_CPP_OVERRIDE{
+        proton::connection_options on_accept() OVERRIDE{
             return proton::connection_options().handler(*(new broker_connection_handler(queues_)));
         }
 
-        void on_error(const std::string& s) PN_CPP_OVERRIDE {
+        void on_error(const std::string& s) OVERRIDE {
             std::cerr << "listen error: " << s << std::endl;
             throw std::runtime_error(s);
         }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/mt/epoll_container.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/mt/epoll_container.cpp b/examples/cpp/mt/epoll_container.cpp
index 9b96610..7f9fb86 100644
--- a/examples/cpp/mt/epoll_container.cpp
+++ b/examples/cpp/mt/epoll_container.cpp
@@ -45,6 +45,8 @@
 #include <sys/eventfd.h>
 #include <unistd.h>
 
+#include "../fake_cpp11.hpp"
+
 // Private implementation
 namespace  {
 
@@ -104,17 +106,17 @@ class epoll_container : public proton::io::container_impl_base {
 
     // Implemenet the proton::mt_container interface
     proton::returned<proton::connection> connect(
-        const std::string& addr, const proton::connection_options& opts) PN_CPP_OVERRIDE;
+        const std::string& addr, const proton::connection_options& opts) OVERRIDE;
 
-    proton::listener listen(const std::string& addr, proton::listen_handler&) PN_CPP_OVERRIDE;
+    proton::listener listen(const std::string& addr, proton::listen_handler&) OVERRIDE;
 
-    void stop_listening(const std::string& addr) PN_CPP_OVERRIDE;
+    void stop_listening(const std::string& addr) OVERRIDE;
 
-    void run() PN_CPP_OVERRIDE;
-    void auto_stop(bool) PN_CPP_OVERRIDE;
-    void stop(const proton::error_condition& err) PN_CPP_OVERRIDE;
+    void run() OVERRIDE;
+    void auto_stop(bool) OVERRIDE;
+    void stop(const proton::error_condition& err) OVERRIDE;
 
-    std::string id() const PN_CPP_OVERRIDE { return id_; }
+    std::string id() const OVERRIDE { return id_; }
 
     // Functions used internally.
     proton::connection add_engine(proton::connection_options opts, int fd, bool server);
@@ -232,7 +234,7 @@ class epoll_event_loop : public proton::event_loop {
 
     epoll_event_loop(pollable& p) : pollable_(p), closed_(false) {}
 
-    bool inject(std::function<void()> f) PN_CPP_OVERRIDE {
+    bool inject(std::function<void()> f) OVERRIDE {
         // Note this is an unbounded work queue.
         // A resource-safe implementation should be bounded.
         lock_guard g(lock_);
@@ -243,7 +245,7 @@ class epoll_event_loop : public proton::event_loop {
         return true;
     }
 
-    bool inject(proton::inject_handler& h) PN_CPP_OVERRIDE {
+    bool inject(proton::inject_handler& h) OVERRIDE {
         return inject(std::bind(&proton::inject_handler::on_inject, &h));
     }
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/queue_browser.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/queue_browser.cpp b/examples/cpp/queue_browser.cpp
index c1f650d..649716b 100644
--- a/examples/cpp/queue_browser.cpp
+++ b/examples/cpp/queue_browser.cpp
@@ -19,17 +19,17 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/receiver_options.hpp"
-#include "proton/source_options.hpp"
-#include "proton/url.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/receiver_options.hpp>
+#include <proton/source_options.hpp>
+#include <proton/url.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 using proton::source_options;
 
@@ -40,13 +40,13 @@ class browser : public proton::messaging_handler {
   public:
     browser(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         proton::connection conn = c.connect(url);
         source_options browsing = source_options().distribution_mode(proton::source::COPY);
         conn.open_receiver(url.path(), proton::receiver_options().source(browsing));
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/selected_recv.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/selected_recv.cpp b/examples/cpp/selected_recv.cpp
index 25fdd36..c7a63d9 100644
--- a/examples/cpp/selected_recv.cpp
+++ b/examples/cpp/selected_recv.cpp
@@ -19,16 +19,16 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/receiver_options.hpp"
-#include "proton/source_options.hpp"
-#include "proton/url.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/receiver_options.hpp>
+#include <proton/source_options.hpp>
+#include <proton/url.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 namespace {
 
@@ -60,14 +60,14 @@ class selected_recv : public proton::messaging_handler {
   public:
     selected_recv(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         proton::source_options opts;
         set_filter(opts, "colour = 'green'");
         proton::connection conn = c.connect(url);
         conn.open_receiver(url.path(), proton::receiver_options().source(opts));
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/server.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/server.cpp b/examples/cpp/server.cpp
index d803b5d..ec24f9f 100644
--- a/examples/cpp/server.cpp
+++ b/examples/cpp/server.cpp
@@ -21,18 +21,18 @@
 
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/tracker.hpp"
-#include "proton/url.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/tracker.hpp>
+#include <proton/url.hpp>
 
 #include <iostream>
 #include <map>
 #include <string>
 #include <cctype>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class server : public proton::messaging_handler {
   private:
@@ -44,7 +44,7 @@ class server : public proton::messaging_handler {
   public:
     server(const std::string &u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         connection = c.connect(url);
         connection.open_receiver(url.path());
 
@@ -59,7 +59,7 @@ class server : public proton::messaging_handler {
         return uc;
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << "Received " << m.body() << std::endl;
 
         std::string reply_to = m.reply_to();

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/server_direct.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/server_direct.cpp b/examples/cpp/server_direct.cpp
index 0c7a76b..220934f 100644
--- a/examples/cpp/server_direct.cpp
+++ b/examples/cpp/server_direct.cpp
@@ -21,11 +21,11 @@
 
 #include "options.hpp"
 
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/sender.hpp"
-#include "proton/source_options.hpp"
-#include "proton/tracker.hpp"
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/sender.hpp>
+#include <proton/source_options.hpp>
+#include <proton/tracker.hpp>
 
 #include <iostream>
 #include <map>
@@ -33,7 +33,7 @@
 #include <sstream>
 #include <cctype>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class server : public proton::messaging_handler {
   private:
@@ -45,7 +45,7 @@ class server : public proton::messaging_handler {
   public:
     server(const std::string &u) : url(u), address_counter(0) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         c.listen(url);
         std::cout << "server listening on " << url << std::endl;
     }
@@ -67,7 +67,7 @@ class server : public proton::messaging_handler {
         return addr.str();
     }
 
-    void on_sender_open(proton::sender &sender) PN_CPP_OVERRIDE {
+    void on_sender_open(proton::sender &sender) OVERRIDE {
         if (sender.source().dynamic()) {
             std::string addr = generate_address();
             sender.open(proton::sender_options().source(proton::source_options().address(addr)));
@@ -75,7 +75,7 @@ class server : public proton::messaging_handler {
         }
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << "Received " << m.body() << std::endl;
 
         std::string reply_to = m.reply_to();

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/simple_recv.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/simple_recv.cpp b/examples/cpp/simple_recv.cpp
index aa7cd1d..2495a28 100644
--- a/examples/cpp/simple_recv.cpp
+++ b/examples/cpp/simple_recv.cpp
@@ -21,18 +21,18 @@
 
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/delivery.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/link.hpp"
-#include "proton/message_id.hpp"
-#include "proton/value.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/delivery.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/link.hpp>
+#include <proton/message_id.hpp>
+#include <proton/value.hpp>
 
 #include <iostream>
 #include <map>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class simple_recv : public proton::messaging_handler {
   private:
@@ -44,12 +44,12 @@ class simple_recv : public proton::messaging_handler {
   public:
     simple_recv(const std::string &s, int c) : url(s), expected(c), received(0) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         receiver = c.open_receiver(url);
         std::cout << "simple_recv listening on " << url << std::endl;
     }
 
-    void on_message(proton::delivery &d, proton::message &msg) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &d, proton::message &msg) OVERRIDE {
         if (msg.id().get<uint64_t>() < received) {
             return; // Ignore duplicate
         }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/simple_send.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/simple_send.cpp b/examples/cpp/simple_send.cpp
index 1ae71f3..3ce72b4 100644
--- a/examples/cpp/simple_send.cpp
+++ b/examples/cpp/simple_send.cpp
@@ -21,16 +21,16 @@
 
 #include "options.hpp"
 
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/tracker.hpp"
-#include "proton/value.hpp"
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/tracker.hpp>
+#include <proton/value.hpp>
 
 #include <iostream>
 #include <map>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 class simple_send : public proton::messaging_handler {
   private:
@@ -43,11 +43,11 @@ class simple_send : public proton::messaging_handler {
   public:
     simple_send(const std::string &s, int c) : url(s), sent(0), confirmed(0), total(c) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         sender = c.open_sender(url);
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         while (s.credit() && sent < total) {
             proton::message msg;
             std::map<std::string, int> m;
@@ -61,7 +61,7 @@ class simple_send : public proton::messaging_handler {
         }
     }
 
-    void on_tracker_accept(proton::tracker &t) PN_CPP_OVERRIDE {
+    void on_tracker_accept(proton::tracker &t) OVERRIDE {
         confirmed++;
 
         if (confirmed == total) {
@@ -70,7 +70,7 @@ class simple_send : public proton::messaging_handler {
         }
     }
 
-    void on_transport_close(proton::transport &) PN_CPP_OVERRIDE {
+    void on_transport_close(proton::transport &) OVERRIDE {
         sent = confirmed;
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/ssl.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/ssl.cpp b/examples/cpp/ssl.cpp
index a4ca46a..91a4230 100644
--- a/examples/cpp/ssl.cpp
+++ b/examples/cpp/ssl.cpp
@@ -19,17 +19,17 @@
  *
  */
 
-#include "proton/connection_options.hpp"
-#include "proton/connection.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/ssl.hpp"
-#include "proton/tracker.hpp"
-#include "proton/transport.hpp"
+#include <proton/connection_options.hpp>
+#include <proton/connection.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/ssl.hpp>
+#include <proton/tracker.hpp>
+#include <proton/transport.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 using proton::connection_options;
 using proton::ssl_client_options;
@@ -47,13 +47,13 @@ std::string find_CN(const std::string &);
 struct server_handler : public proton::messaging_handler {
     std::string url;
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::cout << "Inbound server connection connected via SSL.  Protocol: " <<
             c.transport().ssl().protocol() << std::endl;
         c.container().stop_listening(url);
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
     }
 };
@@ -67,7 +67,7 @@ class hello_world_direct : public proton::messaging_handler {
   public:
     hello_world_direct(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         // Configure listener.  Details vary by platform.
         ssl_certificate server_cert = platform_certificate("tserver", "tserverpw");
         ssl_server_options ssl_srv(server_cert);
@@ -88,20 +88,20 @@ class hello_world_direct : public proton::messaging_handler {
         c.open_sender(url);
     }
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::string subject = c.transport().ssl().remote_subject();
         std::cout << "Outgoing client connection connected via SSL.  Server certificate identity " <<
             find_CN(subject) << std::endl;
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         proton::message m;
         m.body("Hello World!");
         s.send(m);
         s.close();
     }
 
-    void on_tracker_accept(proton::tracker &t) PN_CPP_OVERRIDE {
+    void on_tracker_accept(proton::tracker &t) OVERRIDE {
         // All done.
         t.connection().close();
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/examples/cpp/ssl_client_cert.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/ssl_client_cert.cpp b/examples/cpp/ssl_client_cert.cpp
index e150255..42b6593 100644
--- a/examples/cpp/ssl_client_cert.cpp
+++ b/examples/cpp/ssl_client_cert.cpp
@@ -19,18 +19,18 @@
  *
  */
 
-#include "proton/connection.hpp"
-#include "proton/connection_options.hpp"
-#include "proton/default_container.hpp"
-#include "proton/messaging_handler.hpp"
-#include "proton/sasl.hpp"
-#include "proton/ssl.hpp"
-#include "proton/tracker.hpp"
-#include "proton/transport.hpp"
+#include <proton/connection.hpp>
+#include <proton/connection_options.hpp>
+#include <proton/default_container.hpp>
+#include <proton/messaging_handler.hpp>
+#include <proton/sasl.hpp>
+#include <proton/ssl.hpp>
+#include <proton/tracker.hpp>
+#include <proton/transport.hpp>
 
 #include <iostream>
 
-#include <proton/config.hpp>
+#include "fake_cpp11.hpp"
 
 using proton::connection_options;
 using proton::ssl_client_options;
@@ -49,7 +49,7 @@ static std::string find_CN(const std::string &);
 struct server_handler : public proton::messaging_handler {
     proton::listener listener;
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::cout << "Inbound server connection connected via SSL.  Protocol: " <<
             c.transport().ssl().protocol() << std::endl;
         if (c.transport().sasl().outcome() == sasl::OK) {
@@ -63,7 +63,7 @@ struct server_handler : public proton::messaging_handler {
         listener.stop();
     }
 
-    void on_message(proton::delivery &, proton::message &m) PN_CPP_OVERRIDE {
+    void on_message(proton::delivery &, proton::message &m) OVERRIDE {
         std::cout << m.body() << std::endl;
     }
 };
@@ -77,7 +77,7 @@ class hello_world_direct : public proton::messaging_handler {
   public:
     hello_world_direct(const std::string& u) : url(u) {}
 
-    void on_container_start(proton::container &c) PN_CPP_OVERRIDE {
+    void on_container_start(proton::container &c) OVERRIDE {
         // Configure listener.  Details vary by platform.
         ssl_certificate server_cert = platform_certificate("tserver", "tserverpw");
         std::string client_CA = platform_CA("tclient");
@@ -102,20 +102,20 @@ class hello_world_direct : public proton::messaging_handler {
         c.open_sender(url);
     }
 
-    void on_connection_open(proton::connection &c) PN_CPP_OVERRIDE {
+    void on_connection_open(proton::connection &c) OVERRIDE {
         std::string subject = c.transport().ssl().remote_subject();
         std::cout << "Outgoing client connection connected via SSL.  Server certificate identity " <<
             find_CN(subject) << std::endl;
     }
 
-    void on_sendable(proton::sender &s) PN_CPP_OVERRIDE {
+    void on_sendable(proton::sender &s) OVERRIDE {
         proton::message m;
         m.body("Hello World!");
         s.send(m);
         s.close();
     }
 
-    void on_tracker_accept(proton::tracker &t) PN_CPP_OVERRIDE {
+    void on_tracker_accept(proton::tracker &t) OVERRIDE {
         // All done.
         t.connection().close();
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/annotation_key.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/annotation_key.hpp b/proton-c/bindings/cpp/include/proton/annotation_key.hpp
index e63db3c..019e3d3 100644
--- a/proton-c/bindings/cpp/include/proton/annotation_key.hpp
+++ b/proton-c/bindings/cpp/include/proton/annotation_key.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/internal/scalar_base.hpp"
-#include "proton/symbol.hpp"
+#include "./internal/scalar_base.hpp"
+#include "./symbol.hpp"
 
 namespace proton {
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/binary.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/binary.hpp b/proton-c/bindings/cpp/include/proton/binary.hpp
index 40969f4..b7b7ac1 100644
--- a/proton-c/bindings/cpp/include/proton/binary.hpp
+++ b/proton-c/bindings/cpp/include/proton/binary.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/export.hpp"
-#include "proton/types_fwd.hpp"
+#include "./internal/export.hpp"
+#include "./types_fwd.hpp"
 
 #include <iosfwd>
 #include <vector>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/byte_array.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/byte_array.hpp b/proton-c/bindings/cpp/include/proton/byte_array.hpp
index 2fd638d..d69861a 100644
--- a/proton-c/bindings/cpp/include/proton/byte_array.hpp
+++ b/proton-c/bindings/cpp/include/proton/byte_array.hpp
@@ -20,9 +20,9 @@
  * under the License.
  */
 
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
-#include "proton/types_fwd.hpp"
+#include "./internal/export.hpp"
+#include "./internal/comparable.hpp"
+#include "./types_fwd.hpp"
 
 #include <algorithm>
 #include <iterator>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/data.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/data.hpp b/proton-c/bindings/cpp/include/proton/codec/data.hpp
index 968f243..19df1ed 100644
--- a/proton-c/bindings/cpp/include/proton/codec/data.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/data.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/internal/object.hpp"
-#include "proton/types_fwd.hpp"
-#include "proton/type_id.hpp"
+#include "../internal/object.hpp"
+#include "../types_fwd.hpp"
+#include "../type_id.hpp"
 
 struct pn_data_t;
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/decoder.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/decoder.hpp b/proton-c/bindings/cpp/include/proton/codec/decoder.hpp
index 3363811..bdc2208 100644
--- a/proton-c/bindings/cpp/include/proton/codec/decoder.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/decoder.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/codec/data.hpp"
-#include "proton/internal/type_traits.hpp"
-#include "proton/types_fwd.hpp"
+#include "./data.hpp"
+#include "../internal/type_traits.hpp"
+#include "../types_fwd.hpp"
 
 #include <utility>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/deque.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/deque.hpp b/proton-c/bindings/cpp/include/proton/codec/deque.hpp
index 2b64b0d..2f570a4 100644
--- a/proton-c/bindings/cpp/include/proton/codec/deque.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/deque.hpp
@@ -20,8 +20,8 @@
  * under the License.
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <deque>
 #include <utility>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/encoder.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/encoder.hpp b/proton-c/bindings/cpp/include/proton/codec/encoder.hpp
index a476ffc..6b90ba2 100644
--- a/proton-c/bindings/cpp/include/proton/codec/encoder.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/encoder.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/codec/data.hpp"
-#include "proton/internal/type_traits.hpp"
-#include "proton/types_fwd.hpp"
+#include "./data.hpp"
+#include "../internal/type_traits.hpp"
+#include "../types_fwd.hpp"
 
 namespace proton {
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/forward_list.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/forward_list.hpp b/proton-c/bindings/cpp/include/proton/codec/forward_list.hpp
index 2096ba9..0038b8f 100644
--- a/proton-c/bindings/cpp/include/proton/codec/forward_list.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/forward_list.hpp
@@ -20,8 +20,8 @@
  * under the License.
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <forward_list>
 #include <utility>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/list.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/list.hpp b/proton-c/bindings/cpp/include/proton/codec/list.hpp
index 40d2e7a..a2c71b8 100644
--- a/proton-c/bindings/cpp/include/proton/codec/list.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/list.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <list>
 #include <utility>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/map.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/map.hpp b/proton-c/bindings/cpp/include/proton/codec/map.hpp
index c9287c0..d3b0c4d 100644
--- a/proton-c/bindings/cpp/include/proton/codec/map.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/map.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <map>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/unordered_map.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/unordered_map.hpp b/proton-c/bindings/cpp/include/proton/codec/unordered_map.hpp
index 9be856f..b081ff8 100644
--- a/proton-c/bindings/cpp/include/proton/codec/unordered_map.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/unordered_map.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <unordered_map>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/codec/vector.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/codec/vector.hpp b/proton-c/bindings/cpp/include/proton/codec/vector.hpp
index 0808229..4edae25 100644
--- a/proton-c/bindings/cpp/include/proton/codec/vector.hpp
+++ b/proton-c/bindings/cpp/include/proton/codec/vector.hpp
@@ -22,8 +22,8 @@
  *
  */
 
-#include "proton/codec/encoder.hpp"
-#include "proton/codec/decoder.hpp"
+#include "./encoder.hpp"
+#include "./decoder.hpp"
 
 #include <vector>
 #include <utility>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/config.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/config.hpp b/proton-c/bindings/cpp/include/proton/config.hpp
deleted file mode 100644
index 2e085d0..0000000
--- a/proton-c/bindings/cpp/include/proton/config.hpp
+++ /dev/null
@@ -1,84 +0,0 @@
-#ifndef PROTON_CONFIG_HPP
-#define PROTON_CONFIG_HPP
-
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-/// @cond INTERNAL
-
-/// @file
-///
-/// Configuration macros.  They can be set via -D compiler options or
-/// in code.
-///
-/// On a C++11 compliant compiler, all C++11 features are enabled by
-/// default.  Otherwise they can be enabled or disabled separately
-/// with -D on the compile line.
-
-#ifndef PN_CPP_HAS_CPP11
-#if defined(__cplusplus) && __cplusplus >= 201100
-#define PN_CPP_HAS_CPP11 1
-#else
-#define PN_CPP_HAS_CPP11 0
-#endif
-#endif
-
-#ifndef PN_CPP_HAS_STD_PTR
-#define PN_CPP_HAS_STD_PTR PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_LONG_LONG
-#define PN_CPP_HAS_LONG_LONG PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_NULLPTR
-#define PN_CPP_HAS_NULLPTR PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_RVALUE_REFERENCES
-#define PN_CPP_HAS_RVALUE_REFERENCES PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_OVERRIDE
-#define PN_CPP_HAS_OVERRIDE PN_CPP_HAS_CPP11
-#endif
-
-#if PN_CPP_HAS_OVERRIDE
-#define PN_CPP_OVERRIDE override
-#else
-#define PN_CPP_OVERRIDE
-#endif
-
-#ifndef PN_CPP_HAS_EXPLICIT_CONVERSIONS
-#define PN_CPP_HAS_EXPLICIT_CONVERSIONS PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_DEFAULTED_FUNCTIONS
-#define PN_CPP_HAS_DEFAULTED_FUNCTIONS PN_CPP_HAS_CPP11
-#endif
-
-#ifndef PN_CPP_HAS_DELETED_FUNCTIONS
-#define PN_CPP_HAS_DELETED_FUNCTIONS PN_CPP_HAS_CPP11
-#endif
-
-#endif // PROTON_CONFIG_HPP
-
-/// @endcond

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/connection.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/connection.hpp b/proton-c/bindings/cpp/include/proton/connection.hpp
index a504954..aa8ebc6 100644
--- a/proton-c/bindings/cpp/include/proton/connection.hpp
+++ b/proton-c/bindings/cpp/include/proton/connection.hpp
@@ -22,12 +22,12 @@
  *
  */
 
-#include "proton/export.hpp"
-#include "proton/endpoint.hpp"
-#include "proton/internal/object.hpp"
-#include "proton/session.hpp"
+#include "./internal/export.hpp"
+#include "./endpoint.hpp"
+#include "./internal/object.hpp"
+#include "./session.hpp"
 
-#include "proton/types.h"
+#include <proton/types.h>
 
 #include <string>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/connection_options.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/connection_options.hpp b/proton-c/bindings/cpp/include/proton/connection_options.hpp
index 54c1848..3da485a 100644
--- a/proton-c/bindings/cpp/include/proton/connection_options.hpp
+++ b/proton-c/bindings/cpp/include/proton/connection_options.hpp
@@ -22,12 +22,12 @@
  *
  */
 
-#include "proton/config.hpp"
-#include "proton/export.hpp"
-#include "proton/duration.hpp"
-#include "proton/internal/pn_unique_ptr.hpp"
-#include "proton/reconnect_timer.hpp"
-#include "proton/types_fwd.hpp"
+#include "./internal/config.hpp"
+#include "./internal/export.hpp"
+#include "./duration.hpp"
+#include "./internal/pn_unique_ptr.hpp"
+#include "./reconnect_timer.hpp"
+#include "./types_fwd.hpp"
 
 #include <vector>
 #include <string>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/container.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/container.hpp b/proton-c/bindings/cpp/include/proton/container.hpp
index f7ae36d..97baccb 100644
--- a/proton-c/bindings/cpp/include/proton/container.hpp
+++ b/proton-c/bindings/cpp/include/proton/container.hpp
@@ -24,11 +24,11 @@
 
 // FIXME aconway 2016-05-04: doc
 
-#include "proton/connection_options.hpp"
-#include "proton/error_condition.hpp"
-#include "proton/listener.hpp"
-#include "proton/internal/pn_unique_ptr.hpp"
-#include "proton/thread_safe.hpp"
+#include "./connection_options.hpp"
+#include "./error_condition.hpp"
+#include "./listener.hpp"
+#include "./internal/pn_unique_ptr.hpp"
+#include "./thread_safe.hpp"
 
 #include <string>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/decimal.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/decimal.hpp b/proton-c/bindings/cpp/include/proton/decimal.hpp
index 8ef5023..873931b 100644
--- a/proton-c/bindings/cpp/include/proton/decimal.hpp
+++ b/proton-c/bindings/cpp/include/proton/decimal.hpp
@@ -22,11 +22,11 @@
  *
  */
 
-#include "proton/byte_array.hpp"
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
+#include "./byte_array.hpp"
+#include "./internal/export.hpp"
+#include "./internal/comparable.hpp"
 
-#include "proton/types.h"
+#include <proton/types.h>
 
 #include <iosfwd>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/default_container.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/default_container.hpp b/proton-c/bindings/cpp/include/proton/default_container.hpp
index 8b18304..a050a0f 100644
--- a/proton-c/bindings/cpp/include/proton/default_container.hpp
+++ b/proton-c/bindings/cpp/include/proton/default_container.hpp
@@ -24,7 +24,7 @@
 
 // FIXME aconway 2016-05-04: doc
 
-#include "proton/container.hpp"
+#include "./container.hpp"
 
 namespace proton {
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/delivery.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/delivery.hpp b/proton-c/bindings/cpp/include/proton/delivery.hpp
index c587214..53780a2 100644
--- a/proton-c/bindings/cpp/include/proton/delivery.hpp
+++ b/proton-c/bindings/cpp/include/proton/delivery.hpp
@@ -22,12 +22,12 @@
  *
  */
 
-#include "proton/export.hpp"
-#include "proton/internal/object.hpp"
-#include "proton/transfer.hpp"
+#include "./internal/export.hpp"
+#include "./internal/object.hpp"
+#include "./transfer.hpp"
 
-#include "proton/delivery.h"
-#include "proton/disposition.h"
+#include <proton/delivery.h>
+#include <proton/disposition.h>
 
 namespace proton {
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/duration.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/duration.hpp b/proton-c/bindings/cpp/include/proton/duration.hpp
index 7f32e91..7110051 100644
--- a/proton-c/bindings/cpp/include/proton/duration.hpp
+++ b/proton-c/bindings/cpp/include/proton/duration.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
-#include "proton/types_fwd.hpp"
+#include "./internal/export.hpp"
+#include "./internal/comparable.hpp"
+#include "./types_fwd.hpp"
 
 #include <iosfwd>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/endpoint.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/endpoint.hpp b/proton-c/bindings/cpp/include/proton/endpoint.hpp
index c908bac..4628d35 100644
--- a/proton-c/bindings/cpp/include/proton/endpoint.hpp
+++ b/proton-c/bindings/cpp/include/proton/endpoint.hpp
@@ -22,10 +22,10 @@
  *
  */
 
-#include "proton/config.hpp"
-#include "proton/error_condition.hpp"
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
+#include "./internal/config.hpp"
+#include "./error_condition.hpp"
+#include "./internal/export.hpp"
+#include "./internal/comparable.hpp"
 
 namespace proton {
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/error.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/error.hpp b/proton-c/bindings/cpp/include/proton/error.hpp
index df4c30e..1dbbc9b 100644
--- a/proton-c/bindings/cpp/include/proton/error.hpp
+++ b/proton-c/bindings/cpp/include/proton/error.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/config.hpp"
-#include "proton/export.hpp"
-#include "proton/value.hpp"
+#include "./internal/config.hpp"
+#include "./internal/export.hpp"
+#include "./value.hpp"
 
 #include <stdexcept>
 #include <string>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/error_condition.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/error_condition.hpp b/proton-c/bindings/cpp/include/proton/error_condition.hpp
index 10ffeba..e75e5d0 100644
--- a/proton-c/bindings/cpp/include/proton/error_condition.hpp
+++ b/proton-c/bindings/cpp/include/proton/error_condition.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/export.hpp"
-#include "proton/value.hpp"
-#include "proton/config.hpp"
+#include "./internal/export.hpp"
+#include "./value.hpp"
+#include "./internal/config.hpp"
 
 #include <string>
 #include <iosfwd>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/event_loop.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/event_loop.hpp b/proton-c/bindings/cpp/include/proton/event_loop.hpp
index 9b3d69a..446295a 100644
--- a/proton-c/bindings/cpp/include/proton/event_loop.hpp
+++ b/proton-c/bindings/cpp/include/proton/event_loop.hpp
@@ -22,7 +22,7 @@
  *
  */
 
-#include "proton/config.hpp"
+#include "./internal/config.hpp"
 
 #include <functional>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/export.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/export.hpp b/proton-c/bindings/cpp/include/proton/export.hpp
deleted file mode 100644
index 8dc1204..0000000
--- a/proton-c/bindings/cpp/include/proton/export.hpp
+++ /dev/null
@@ -1,57 +0,0 @@
-#ifndef PROTON_EXPORT_HPP
-#define PROTON_EXPORT_HPP
-
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-/// @cond INTERNAL
-
-/// import/export macros
-#if defined(WIN32) && !defined(PN_CPP_DECLARE_STATIC)
-  //
-  // Import and Export definitions for Windows:
-  //
-#  define PN_CPP_EXPORT __declspec(dllexport)
-#  define PN_CPP_IMPORT __declspec(dllimport)
-#  define PN_CPP_CLASS_EXPORT
-#  define PN_CPP_CLASS_IMPORT
-#else
-  //
-  // Non-Windows (Linux, etc.) definitions:
-  //
-#  define PN_CPP_EXPORT __attribute ((visibility ("default")))
-#  define PN_CPP_IMPORT
-#  define PN_CPP_CLASS_EXPORT __attribute ((visibility ("default")))
-#  define PN_CPP_CLASS_IMPORT
-#endif
-
-// For qpid-proton-cpp library symbols
-#ifdef qpid_proton_cpp_EXPORTS
-#  define PN_CPP_EXTERN PN_CPP_EXPORT
-#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_EXPORT
-#else
-#  define PN_CPP_EXTERN PN_CPP_IMPORT
-#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_IMPORT
-#endif
-
-/// @endcond
-
-#endif // PROTON_EXPORT_HPP

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/config.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/config.hpp b/proton-c/bindings/cpp/include/proton/internal/config.hpp
new file mode 100644
index 0000000..ce45118
--- /dev/null
+++ b/proton-c/bindings/cpp/include/proton/internal/config.hpp
@@ -0,0 +1,84 @@
+#ifndef PROTON_INTERNAL_CONFIG_HPP
+#define PROTON_INTERNAL_CONFIG_HPP
+
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+/// @cond INTERNAL
+
+/// @file
+///
+/// Configuration macros.  They can be set via -D compiler options or
+/// in code.
+///
+/// On a C++11 compliant compiler, all C++11 features are enabled by
+/// default.  Otherwise they can be enabled or disabled separately
+/// with -D on the compile line.
+
+#ifndef PN_CPP_HAS_CPP11
+#if defined(__cplusplus) && __cplusplus >= 201100
+#define PN_CPP_HAS_CPP11 1
+#else
+#define PN_CPP_HAS_CPP11 0
+#endif
+#endif
+
+#ifndef PN_CPP_HAS_STD_PTR
+#define PN_CPP_HAS_STD_PTR PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_LONG_LONG
+#define PN_CPP_HAS_LONG_LONG PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_NULLPTR
+#define PN_CPP_HAS_NULLPTR PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_RVALUE_REFERENCES
+#define PN_CPP_HAS_RVALUE_REFERENCES PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_OVERRIDE
+#define PN_CPP_HAS_OVERRIDE PN_CPP_HAS_CPP11
+#endif
+
+#if PN_CPP_HAS_OVERRIDE
+#define PN_CPP_OVERRIDE override
+#else
+#define PN_CPP_OVERRIDE
+#endif
+
+#ifndef PN_CPP_HAS_EXPLICIT_CONVERSIONS
+#define PN_CPP_HAS_EXPLICIT_CONVERSIONS PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_DEFAULTED_FUNCTIONS
+#define PN_CPP_HAS_DEFAULTED_FUNCTIONS PN_CPP_HAS_CPP11
+#endif
+
+#ifndef PN_CPP_HAS_DELETED_FUNCTIONS
+#define PN_CPP_HAS_DELETED_FUNCTIONS PN_CPP_HAS_CPP11
+#endif
+
+#endif // PROTON_INTERNAL_CONFIG_HPP
+
+/// @endcond

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/export.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/export.hpp b/proton-c/bindings/cpp/include/proton/internal/export.hpp
new file mode 100644
index 0000000..c38ed95
--- /dev/null
+++ b/proton-c/bindings/cpp/include/proton/internal/export.hpp
@@ -0,0 +1,57 @@
+#ifndef PROTON_INTERNAL_EXPORT_HPP
+#define PROTON_INTERNAL_EXPORT_HPP
+
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+/// @cond INTERNAL
+
+/// import/export macros
+#if defined(WIN32) && !defined(PN_CPP_DECLARE_STATIC)
+  //
+  // Import and Export definitions for Windows:
+  //
+#  define PN_CPP_EXPORT __declspec(dllexport)
+#  define PN_CPP_IMPORT __declspec(dllimport)
+#  define PN_CPP_CLASS_EXPORT
+#  define PN_CPP_CLASS_IMPORT
+#else
+  //
+  // Non-Windows (Linux, etc.) definitions:
+  //
+#  define PN_CPP_EXPORT __attribute ((visibility ("default")))
+#  define PN_CPP_IMPORT
+#  define PN_CPP_CLASS_EXPORT __attribute ((visibility ("default")))
+#  define PN_CPP_CLASS_IMPORT
+#endif
+
+// For qpid-proton-cpp library symbols
+#ifdef qpid_proton_cpp_EXPORTS
+#  define PN_CPP_EXTERN PN_CPP_EXPORT
+#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_EXPORT
+#else
+#  define PN_CPP_EXTERN PN_CPP_IMPORT
+#  define PN_CPP_CLASS_EXTERN PN_CPP_CLASS_IMPORT
+#endif
+
+/// @endcond
+
+#endif // PROTON_INTERNAL_EXPORT_HPP

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/object.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/object.hpp b/proton-c/bindings/cpp/include/proton/internal/object.hpp
index 4ca7e0a..82e941c 100644
--- a/proton-c/bindings/cpp/include/proton/internal/object.hpp
+++ b/proton-c/bindings/cpp/include/proton/internal/object.hpp
@@ -22,9 +22,9 @@
  *
  */
 
-#include "proton/config.hpp"
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
+#include "./config.hpp"
+#include "export.hpp"
+#include "./comparable.hpp"
 
 #include <memory>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/pn_unique_ptr.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/pn_unique_ptr.hpp b/proton-c/bindings/cpp/include/proton/internal/pn_unique_ptr.hpp
index b14b442..4983883 100644
--- a/proton-c/bindings/cpp/include/proton/internal/pn_unique_ptr.hpp
+++ b/proton-c/bindings/cpp/include/proton/internal/pn_unique_ptr.hpp
@@ -22,7 +22,7 @@
  *
  */
 
-#include "proton/config.hpp"
+#include "./config.hpp"
 
 #include <memory>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/scalar_base.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/scalar_base.hpp b/proton-c/bindings/cpp/include/proton/internal/scalar_base.hpp
index b68daf4..68b0272 100644
--- a/proton-c/bindings/cpp/include/proton/internal/scalar_base.hpp
+++ b/proton-c/bindings/cpp/include/proton/internal/scalar_base.hpp
@@ -22,17 +22,17 @@
  *
  */
 
-#include "proton/binary.hpp"
-#include "proton/decimal.hpp"
-#include "proton/error.hpp"
-#include "proton/export.hpp"
-#include "proton/internal/comparable.hpp"
-#include "proton/internal/type_traits.hpp"
-#include "proton/symbol.hpp"
-#include "proton/timestamp.hpp"
-#include "proton/type_id.hpp"
-#include "proton/types_fwd.hpp"
-#include "proton/uuid.hpp"
+#include "../binary.hpp"
+#include "../decimal.hpp"
+#include "../error.hpp"
+#include "export.hpp"
+#include "./comparable.hpp"
+#include "./type_traits.hpp"
+#include "../symbol.hpp"
+#include "../timestamp.hpp"
+#include "../type_id.hpp"
+#include "../types_fwd.hpp"
+#include "../uuid.hpp"
 
 #include <iosfwd>
 #include <string>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/internal/type_traits.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/internal/type_traits.hpp b/proton-c/bindings/cpp/include/proton/internal/type_traits.hpp
index 3798cee..999b321 100644
--- a/proton-c/bindings/cpp/include/proton/internal/type_traits.hpp
+++ b/proton-c/bindings/cpp/include/proton/internal/type_traits.hpp
@@ -29,9 +29,9 @@
 /// Also provides workarounds for missing type_traits classes on older
 /// C++ compilers.
 
-#include "proton/config.hpp"
-#include "proton/types_fwd.hpp"
-#include "proton/type_id.hpp"
+#include "./config.hpp"
+#include "../types_fwd.hpp"
+#include "../type_id.hpp"
 
 namespace proton {
 namespace internal {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/1a9470a2/proton-c/bindings/cpp/include/proton/io/connection_engine.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/io/connection_engine.hpp b/proton-c/bindings/cpp/include/proton/io/connection_engine.hpp
index 13584da..62c0230 100644
--- a/proton-c/bindings/cpp/include/proton/io/connection_engine.hpp
+++ b/proton-c/bindings/cpp/include/proton/io/connection_engine.hpp
@@ -22,15 +22,15 @@
  *
  */
 
-#include "proton/config.hpp"
-#include "proton/connection.hpp"
-#include "proton/connection_options.hpp"
-#include "proton/error.hpp"
-#include "proton/error_condition.hpp"
-#include "proton/export.hpp"
-#include "proton/internal/pn_unique_ptr.hpp"
-#include "proton/transport.hpp"
-#include "proton/types.hpp"
+#include "../internal/config.hpp"
+#include "../connection.hpp"
+#include "../connection_options.hpp"
+#include "../error.hpp"
+#include "../error_condition.hpp"
+#include "../internal/export.hpp"
+#include "../internal/pn_unique_ptr.hpp"
+#include "../transport.hpp"
+#include "../types.hpp"
 
 #include <cstddef>
 #include <utility>


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