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 2017/12/08 21:14:04 UTC

[1/4] qpid-proton git commit: PROTON-1651: Fix typos found by way of spell check (Thanks, Jiri)

Repository: qpid-proton
Updated Branches:
  refs/heads/master 85755ac4b -> 2b033949c


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/log.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/log.h b/proton-c/include/proton/log.h
index 35538f7..2f2046b 100644
--- a/proton-c/include/proton/log.h
+++ b/proton-c/include/proton/log.h
@@ -45,7 +45,7 @@ typedef void (*pn_logger_t)(const char *message);
 /**
  * Enable/disable global logging.
  *
- * By default, logging is enabled by envionment variable PN_TRACE_LOG.
+ * By default, logging is enabled by environment variable PN_TRACE_LOG.
  * Calling this function overrides the environment setting.
  */
 PN_EXTERN void pn_log_enable(bool enabled);
@@ -55,7 +55,7 @@ PN_EXTERN void pn_log_enable(bool enabled);
  *
  * By default a logger that prints to stderr is installed.
  *  
- * @param logger is called with each log messsage if logging is enabled.
+ * @param logger is called with each log message if logging is enabled.
  * Passing 0 disables logging regardless of pn_log_enable() or environment settings.
  */
 PN_EXTERN void pn_log_logger(pn_logger_t logger);

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/message.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/message.h b/proton-c/include/proton/message.h
index d379436..f9d62b0 100644
--- a/proton-c/include/proton/message.h
+++ b/proton-c/include/proton/message.h
@@ -280,7 +280,7 @@ PN_EXTERN pn_data_t *    pn_message_id                    (pn_message_t *msg);
  * 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
- * ::pn_atom_t descriminated union. See ::pn_atom_t for details on how
+ * ::pn_atom_t discriminated union. See ::pn_atom_t for details on how
  * to access the value.
  *
  * @param[in] msg a message object
@@ -437,7 +437,7 @@ PN_EXTERN pn_data_t *    pn_message_correlation_id        (pn_message_t *msg);
  *
  * 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
- * ::pn_atom_t descriminated union. See ::pn_atom_t for details on how
+ * ::pn_atom_t discriminated union. See ::pn_atom_t for details on how
  * to access the value.
  *
  * @param[in] msg a message object

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/messenger.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/messenger.h b/proton-c/include/proton/messenger.h
index 3caf272..0445865 100644
--- a/proton-c/include/proton/messenger.h
+++ b/proton-c/include/proton/messenger.h
@@ -82,7 +82,7 @@ extern "C" {
  * Sending & Receiving Messages
  * ============================
  *
- * The messenger API works in conjuction with the ::pn_message_t API.
+ * The messenger API works in conjunction with the ::pn_message_t API.
  * A ::pn_message_t is a mutable holder of message content.
  *
  * The ::pn_messenger_put() operation copies content from the supplied
@@ -130,7 +130,7 @@ extern "C" {
  * and then return. You can then look at the number of incoming and
  * outgoing messages to see how much outstanding work still remains.
  *
- * Authentication Mechanims
+ * Authentication Mechanisms
  * ========================
  *
  * The messenger API authenticates using some specific mechanisms. In prior versions
@@ -726,7 +726,7 @@ PNX_EXTERN int pn_messenger_receiving(pn_messenger_t *messenger);
  *
  * The get operation copies the message data from the head of the
  * messenger's incoming queue into the provided ::pn_message_t object.
- * If provided ::pn_message_t pointer is NULL, the head essage will be
+ * If provided ::pn_message_t pointer is NULL, the head message will be
  * discarded. This operation will return ::PN_EOS if there are no
  * messages left on the incoming queue.
  *
@@ -756,7 +756,7 @@ PNX_EXTERN pn_tracker_t pn_messenger_incoming_tracker(pn_messenger_t *messenger)
  * Get the subscription of the message most recently retrieved by ::pn_messenger_get().
  *
  * This operation will return NULL if ::pn_messenger_get() has never
- * been succesfully called.
+ * been successfully called.
  *
  * @param[in] messenger a messenger object
  * @return a pn_subscription_t or NULL
@@ -1035,7 +1035,7 @@ PNX_EXTERN pn_millis_t
                                          const char *address);
 
 /**
- * Sets the SSL peer authentiacation mode required when a trust
+ * Sets the SSL peer authentication mode required when a trust
  * certificate is used.
  *
  * @param[in] messenger a messenger object

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/reactor.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/reactor.h b/proton-c/include/proton/reactor.h
index f617b0d..e8a8864 100644
--- a/proton-c/include/proton/reactor.h
+++ b/proton-c/include/proton/reactor.h
@@ -74,7 +74,7 @@ PNX_EXTERN pn_error_t *pn_reactor_error(pn_reactor_t *reactor);
 /**
  * Create an outgoing connection that will be managed by the reactor.
  *
- * The reator's pn_iohandler will create a socket connection to the host
+ * The reactor's pn_iohandler will create a socket connection to the host
  * once the connection is opened.
  *
  * @param[in] reactor the reactor that will own the connection.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/sasl.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/sasl.h b/proton-c/include/proton/sasl.h
index 671ffec..90b08f5 100644
--- a/proton-c/include/proton/sasl.h
+++ b/proton-c/include/proton/sasl.h
@@ -80,7 +80,7 @@ PN_EXTERN pn_sasl_t *pn_sasl(pn_transport_t *transport);
  * All implementations of Proton support ANONYMOUS and EXTERNAL on both
  * client and server sides and PLAIN on the client side.
  *
- * Extended SASL implememtations use an external library (Cyrus SASL)
+ * Extended SASL implementations use an external library (Cyrus SASL)
  * to support other mechanisms beyond these basic ones.
  *
  * @return true if we support extended SASL negotiation, false if we only support basic negotiation.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/selectable.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/selectable.h b/proton-c/include/proton/selectable.h
index 8c0a4db..9bfb867 100644
--- a/proton-c/include/proton/selectable.h
+++ b/proton-c/include/proton/selectable.h
@@ -203,7 +203,7 @@ PNX_EXTERN void pn_selectable_expired(pn_selectable_t *selectable);
  * Check if a selectable is registered.
  *
  * This flag is set via ::pn_selectable_set_registered() and can be
- * used for tracking whether a given selectable has been registerd
+ * used for tracking whether a given selectable has been registered
  * with an external event loop.
  *
  * @param[in] selectable
@@ -255,7 +255,7 @@ PNX_EXTERN void pn_selectable_free(pn_selectable_t *selectable);
  * Configure a selectable with a set of callbacks that emit readable,
  * writable, and expired events into the supplied collector.
  *
- * @param[in] selectable a selectable objet
+ * @param[in] selectable a selectable object
  * @param[in] collector a collector object
  */
 PNX_EXTERN void pn_selectable_collect(pn_selectable_t *selectable, pn_collector_t *collector);

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/terminus.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/terminus.h b/proton-c/include/proton/terminus.h
index c18fb3e..b2344c0 100644
--- a/proton-c/include/proton/terminus.h
+++ b/proton-c/include/proton/terminus.h
@@ -85,7 +85,7 @@ typedef enum {
  * Expiry policy of an AMQP terminus.
  *
  * An orphaned terminus can only exist for the timeout configured by
- * ::pn_terminus_set_timeout. The expiry policy determins when a
+ * ::pn_terminus_set_timeout. The expiry policy determines when a
  * terminus is considered orphaned, i.e. when the expiry timer starts
  * counting down.
  */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/transport.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/transport.h b/proton-c/include/proton/transport.h
index a32505f..84494f1 100644
--- a/proton-c/include/proton/transport.h
+++ b/proton-c/include/proton/transport.h
@@ -180,7 +180,7 @@ PN_EXTERN bool pn_transport_is_authenticated(pn_transport_t *transport);
  *
  * There are several ways within the AMQP protocol suite to get encrypted connections:
  * - Use TLS
- * - Use a SASL with a mechanism that supports saecurity layers
+ * - Use a SASL with a mechanism that supports security layers
  *
  * The default if this option is not set is to allow unencrypted connections.
  *
@@ -204,7 +204,7 @@ PN_EXTERN bool pn_transport_is_encrypted(pn_transport_t *transport);
  * Get additional information about the condition of the transport.
  *
  * When a PN_TRANSPORT_ERROR event occurs, this operation can be used
- * to access the details of the error condtion.
+ * to access the details of the error condition.
  *
  * The pointer returned by this operation is valid until the
  * transport object is freed.
@@ -364,7 +364,7 @@ PN_EXTERN uint16_t pn_transport_get_channel_max(pn_transport_t *transport);
  * Set the maximum allowed channel number for a transport.
  * 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
+ * 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
@@ -474,7 +474,7 @@ PN_EXTERN ssize_t pn_transport_output(pn_transport_t *transport, char *bytes, si
  * 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
+ * indicated, further details can be obtained from
  * ::pn_transport_error. Calls to ::pn_transport_process may alter the
  * value of this pointer. See ::pn_transport_process for details.
  *
@@ -487,7 +487,7 @@ PN_EXTERN ssize_t pn_transport_capacity(pn_transport_t *transport);
  * Get the transport's tail pointer.
  *
  * The amount of free space following this pointer is reported by
- * ::pn_transport_capacity. Calls to ::pn_transport_process may alther
+ * ::pn_transport_capacity. Calls to ::pn_transport_process may alter
  * the value of this pointer. See ::pn_transport_process for details.
  *
  * @param[in] transport the transport
@@ -498,10 +498,10 @@ PN_EXTERN char *pn_transport_tail(pn_transport_t *transport);
 /**
  * Pushes the supplied bytes into the tail of the transport.
  *
- * This is equivalent to copying @c size bytes afther the tail pointer
+ * This is equivalent to copying @c size bytes after the tail pointer
  * and then calling ::pn_transport_process with an argument of @c
  * size. Only some of the bytes will be copied if there is
- * insufficienty capacity available. Use ::pn_transport_capacity to
+ * insufficient capacity available. Use ::pn_transport_capacity to
  * determine how much capacity the transport has.
  *
  * @param[in] transport the transport

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/type_compat.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/type_compat.h b/proton-c/include/proton/type_compat.h
index b6d7760..12a96e6 100644
--- a/proton-c/include/proton/type_compat.h
+++ b/proton-c/include/proton/type_compat.h
@@ -63,7 +63,7 @@
 # define PNI_DEFINE_SSIZE_T
 #endif
 
-/* Determinine default action */
+/* Determine default action */
 #ifndef _MSC_VER
 /* Not Windows and not using Visual Studio */
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/mllib/dom.py
----------------------------------------------------------------------
diff --git a/proton-c/mllib/dom.py b/proton-c/mllib/dom.py
index 9421504..d297cb5 100644
--- a/proton-c/mllib/dom.py
+++ b/proton-c/mllib/dom.py
@@ -65,7 +65,7 @@ class Component:
 class DispatchError(Exception):
 
   def __init__(self, scope, f):
-    msg = "no such attribtue"
+    msg = "no such attribute"
 
 class Dispatcher:
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/core/transport.c
----------------------------------------------------------------------
diff --git a/proton-c/src/core/transport.c b/proton-c/src/core/transport.c
index 21d62db..48eddd2 100644
--- a/proton-c/src/core/transport.c
+++ b/proton-c/src/core/transport.c
@@ -338,7 +338,7 @@ ssize_t pn_io_layer_input_autodetect(pn_transport_t *transport, unsigned int lay
     }
     if (transport->encryption_required && !pn_transport_is_encrypted(transport)) {
       pn_do_error(transport, "amqp:connection:policy-error",
-                  "Client connection unencryted - forbidden");
+                  "Client connection unencrypted - forbidden");
       pn_set_error_layer(transport);
       return 8;
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/libqpid-proton-proactor.pc.in
----------------------------------------------------------------------
diff --git a/proton-c/src/libqpid-proton-proactor.pc.in b/proton-c/src/libqpid-proton-proactor.pc.in
index 19007a8..c9f7ddb 100644
--- a/proton-c/src/libqpid-proton-proactor.pc.in
+++ b/proton-c/src/libqpid-proton-proactor.pc.in
@@ -23,7 +23,7 @@ libdir=@LIBDIR@
 includedir=@INCLUDEDIR@
 
 Name: Proton Proactor
-Description: Qpid Proton C proative IO library
+Description: Qpid Proton C proactive IO library
 Version: @PN_VERSION@
 URL: http://qpid.apache.org/proton/
 Libs: -L${libdir} -lqpid-proton-proactor

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/proactor/epoll.c
----------------------------------------------------------------------
diff --git a/proton-c/src/proactor/epoll.c b/proton-c/src/proactor/epoll.c
index 1fb0c9e..4f3890f 100644
--- a/proton-c/src/proactor/epoll.c
+++ b/proton-c/src/proactor/epoll.c
@@ -397,7 +397,7 @@ struct pn_proactor_t {
   bool need_inactive;
   bool need_timeout;
   bool timeout_set; /* timeout has been set by user and not yet cancelled or generated event */
-  bool timeout_processed;  /* timout event dispatched in the most recent event batch */
+  bool timeout_processed;  /* timeout event dispatched in the most recent event batch */
   bool timer_armed; /* timer is armed in epoll */
   bool shutting_down;
   // wake subsystem
@@ -521,7 +521,7 @@ typedef struct pconnection_t {
   bool timer_armed;
   bool queued_disconnect;     /* deferred from pn_proactor_disconnect() */
   pn_condition_t *disconnect_condition;
-  ptimer_t timer;  // TODO: review one timerfd per connectoin
+  ptimer_t timer;  // TODO: review one timerfd per connection
   // Following values only changed by (sole) working context:
   uint32_t current_arm;  // active epoll io events
   bool connected;
@@ -951,7 +951,7 @@ static inline bool pconnection_work_pending(pconnection_t *pc) {
 static void pconnection_done(pconnection_t *pc) {
   bool notify = false;
   lock(&pc->context.mutex);
-  pc->context.working = false;  // So we can wake() ourself if necessary.  We remain the defacto
+  pc->context.working = false;  // So we can wake() ourself if necessary.  We remain the de facto
                                 // working context while the lock is held.
   pc->hog_count = 0;
   if (pconnection_has_event(pc) || pconnection_work_pending(pc)) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/proactor/libuv.c
----------------------------------------------------------------------
diff --git a/proton-c/src/proactor/libuv.c b/proton-c/src/proactor/libuv.c
index 4819646..750c743 100644
--- a/proton-c/src/proactor/libuv.c
+++ b/proton-c/src/proactor/libuv.c
@@ -39,7 +39,7 @@
 
 #include <uv.h>
 
-/* All asserts are cheap and should remain in a release build for debugability */
+/* All asserts are cheap and should remain in a release build for debuggability */
 #undef NDEBUG
 #include <assert.h>
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/proactor/win_iocp.c
----------------------------------------------------------------------
diff --git a/proton-c/src/proactor/win_iocp.c b/proton-c/src/proactor/win_iocp.c
index 0d276e8..ca0c5c4 100644
--- a/proton-c/src/proactor/win_iocp.c
+++ b/proton-c/src/proactor/win_iocp.c
@@ -123,7 +123,7 @@ struct iocpdesc_t {
   bool read_in_progress;
   write_pipeline_t *pipeline;
   read_result_t *read_result;
-  bool bound;          // associted with the completion port
+  bool bound;          // associated with the completion port
   bool closing;        // close called by application
   bool read_closed;    // EOF or read error
   bool write_closed;   // shutdown sent or write error
@@ -3256,7 +3256,7 @@ static bool proactor_remove(pcontext_t *ctx) {
     if (--ctx->disconnect_ops == 0) {
       --p->disconnects_pending;
     }
-    else                  // procator_disconnect() still processing
+    else                  // proactor_disconnect() still processing
       can_free = false;   // this psocket
   }
   else {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/reactor/connection.c
----------------------------------------------------------------------
diff --git a/proton-c/src/reactor/connection.c b/proton-c/src/reactor/connection.c
index 4bc8b8d..090947c 100644
--- a/proton-c/src/reactor/connection.c
+++ b/proton-c/src/reactor/connection.c
@@ -189,7 +189,7 @@ void pni_handle_bound(pn_reactor_t *reactor, pn_event_t *event) {
       pn_transport_close_head(transport);
   } else {
       pn_socket_t sock = pn_connect(pni_reactor_io(reactor), host, port);
-      // invalid sockets are ignored by poll, so we need to do this manualy
+      // invalid sockets are ignored by poll, so we need to do this manually
       if (sock == PN_INVALID_SOCKET) {
           pn_condition_t *cond = pn_transport_condition(transport);
           pn_condition_set_name(cond, "proton:io");

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/sasl/sasl.c
----------------------------------------------------------------------
diff --git a/proton-c/src/sasl/sasl.c b/proton-c/src/sasl/sasl.c
index bb95429..f015514 100644
--- a/proton-c/src/sasl/sasl.c
+++ b/proton-c/src/sasl/sasl.c
@@ -367,7 +367,7 @@ void pnx_sasl_set_desired_state(pn_transport_t *transport, enum pnx_sasl_state d
   }
 }
 
-// Look for symbol in the mech include list - not particlarly efficient,
+// Look for symbol in the mech include list - not particularly efficient,
 // but probably not used enough to matter.
 //
 // Note that if there is no inclusion list then every mech is implicitly included.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/ssl/schannel.c
----------------------------------------------------------------------
diff --git a/proton-c/src/ssl/schannel.c b/proton-c/src/ssl/schannel.c
index 7469095..b541c96 100644
--- a/proton-c/src/ssl/schannel.c
+++ b/proton-c/src/ssl/schannel.c
@@ -1409,7 +1409,7 @@ static bool grow_inbuf2(pn_transport_t *transport, size_t minimum_size) {
     if (old_capacity >= max_frame) {
       //  already big enough
       ssl_log(transport, "Application expecting %d bytes (> negotiated maximum frame)\n", new_capacity);
-      ssl_failed(transport, "TLS: transport maximimum frame size error");
+      ssl_failed(transport, "TLS: transport maximum frame size error");
       return false;
     }
   }
@@ -1450,7 +1450,7 @@ static void start_ssl_shutdown(pn_transport_t *transport)
   desc.pBuffers = &shutBuff;
   ApplyControlToken(&ssl->ctxt_handle, &desc);
 
-  // Next handshake will generate the shudown alert token
+  // Next handshake will generate the shutdown alert token
   ssl_handshake(transport);
 }
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/tests/proactor.c
----------------------------------------------------------------------
diff --git a/proton-c/src/tests/proactor.c b/proton-c/src/tests/proactor.c
index 3137da0..b0efa55 100644
--- a/proton-c/src/tests/proactor.c
+++ b/proton-c/src/tests/proactor.c
@@ -356,7 +356,7 @@ static pn_event_type_t listen_abort_handler(test_handler_t *th, pn_event_t *e) {
   }
 }
 
-/* Verify that pn_transport_close_head/tail aborts a connection without an AMQP protoocol close */
+/* Verify that pn_transport_close_head/tail aborts a connection without an AMQP protocol close */
 static void test_abort(test_t *t) {
   test_proactor_t tps[] = { test_proactor(t, open_close_handler), test_proactor(t, listen_abort_handler) };
   pn_proactor_t *client = tps[0].proactor;
@@ -415,7 +415,7 @@ static pn_event_type_t listen_refuse_handler(test_handler_t *th, pn_event_t *e)
   }
 }
 
-/* Verify that pn_transport_close_head/tail aborts a connection without an AMQP protoocol close */
+/* Verify that pn_transport_close_head/tail aborts a connection without an AMQP protocol close */
 static void test_refuse(test_t *t) {
   test_proactor_t tps[] = { test_proactor(t, open_close_handler), test_proactor(t, listen_refuse_handler) };
   pn_proactor_t *client = tps[0].proactor;
@@ -846,7 +846,7 @@ static void test_parse_addr(test_t *t) {
   TEST_STR_EQUAL(t, "5672", port);
 }
 
-/* Test pn_proactor_addr funtions */
+/* Test pn_proactor_addr functions */
 
 static void test_netaddr(test_t *t) {
   test_proactor_t tps[] ={ test_proactor(t, open_wake_handler), test_proactor(t, listen_handler) };
@@ -1003,7 +1003,7 @@ static pn_event_type_t message_stream_handler(test_handler_t *th, pn_event_t *e)
      return PN_CONNECTION_WAKE;
    }
 
-   case PN_DELIVERY: {          /* Receive a delvery - smaller than a chunk? */
+   case PN_DELIVERY: {          /* Receive a delivery - smaller than a chunk? */
      pn_delivery_t *dlv = pn_event_delivery(e);
      if (pn_delivery_readable(dlv)) {
        ssize_t n = pn_delivery_pending(dlv);

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/tests/refcount.c
----------------------------------------------------------------------
diff --git a/proton-c/src/tests/refcount.c b/proton-c/src/tests/refcount.c
index 267c861..487f115 100644
--- a/proton-c/src/tests/refcount.c
+++ b/proton-c/src/tests/refcount.c
@@ -234,7 +234,7 @@ static void test_decref_order(int *indexes, void **objects) {
     }
     for (int j = i+1; j < 4; j++) {
       // everything we haven't decreffed yet should have a refcount of
-      // 2 unless it has a descendent that has not been decrefed (or
+      // 2 unless it has a descendant that has not been decrefed (or
       // it has no child) in which case it should have a refcount of 1
       int idx = indexes[j];
       void *obj = objects[idx];

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/tests/test_port.h
----------------------------------------------------------------------
diff --git a/proton-c/src/tests/test_port.h b/proton-c/src/tests/test_port.h
index 959e597..b252dd9 100644
--- a/proton-c/src/tests/test_port.h
+++ b/proton-c/src/tests/test_port.h
@@ -20,7 +20,7 @@
  * under the License.
  */
 
-/* Some simple platform-secifics to acquire an unused socket */
+/* Some simple platform-specifics to acquire an unused socket */
 
 #include <stdio.h>
 #include <stdlib.h>

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/src/tests/test_tools.h
----------------------------------------------------------------------
diff --git a/proton-c/src/tests/test_tools.h b/proton-c/src/tests/test_tools.h
index f34b790..11354ee 100644
--- a/proton-c/src/tests/test_tools.h
+++ b/proton-c/src/tests/test_tools.h
@@ -47,7 +47,7 @@ typedef struct test_t {
 } test_t;
 
 /* Internal, use macros. Print error message and increase the t->errors count.
-   All output from test marcros goes to stderr so it interleaves with PN_TRACE logs.
+   All output from test macros goes to stderr so it interleaves with PN_TRACE logs.
 */
 void test_vlogf_(test_t *t, const char *prefix, const char* expr,
                  const char* file, int line, const char *fmt, va_list ap)

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/javascript/codec.js
----------------------------------------------------------------------
diff --git a/tests/javascript/codec.js b/tests/javascript/codec.js
index 193c878..5110f4f 100755
--- a/tests/javascript/codec.js
+++ b/tests/javascript/codec.js
@@ -520,7 +520,7 @@ if (typeof process === 'object' && typeof require === 'function') {
     
         assert(data.format() === this.data.format());
     
-        // Deserialise from the copied Data instance into a new JavaScript Object.
+        // Deserialize from the copied Data instance into a new JavaScript Object.
         data.rewind();
         assert(data.next());
         var copy = data.getObject();

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/javascript/message.js
----------------------------------------------------------------------
diff --git a/tests/javascript/message.js b/tests/javascript/message.js
index e714922..8e6ec2e 100755
--- a/tests/javascript/message.js
+++ b/tests/javascript/message.js
@@ -280,7 +280,7 @@ if (typeof process === 'object' && typeof require === 'function') {
     };
 
     /**
-     * This test tests the transparent serialisation and deserialisation of JavaScript
+     * This test tests the transparent serialization and deserialization of JavaScript
      * Objects using the AMQP type system (this is the default behaviour).
      */
     CodecTest.testRoundTripBodyObject = function() {
@@ -301,7 +301,7 @@ if (typeof process === 'object' && typeof require === 'function') {
     };
 
     /**
-     * This test tests the transparent serialisation and deserialisation of JavaScript
+     * This test tests the transparent serialization and deserialization of JavaScript
      * Objects as JSON. In this case the "on-the-wire" representation is an AMQP binary
      * stored in the AMQP data section.
      */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/perf/README.txt
----------------------------------------------------------------------
diff --git a/tests/perf/README.txt b/tests/perf/README.txt
index 3805ad1..5f01ae9 100644
--- a/tests/perf/README.txt
+++ b/tests/perf/README.txt
@@ -6,5 +6,5 @@ connection on the loopback interface.  The latter is timed.  This
 provides a crude view of the overhead of the Proton library alone
 (CMake target "quick_perf_c") or with a language binding.  It is most
 useful for verifying a lack of performance degradation on a large
-ckeckin or between releases.  It probably says little about expected
+check-in or between releases.  It probably says little about expected
 performance on a physical network or for a particular application.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/perf/quick_perf.py
----------------------------------------------------------------------
diff --git a/tests/perf/quick_perf.py b/tests/perf/quick_perf.py
index 7af57d2..4371fb4 100644
--- a/tests/perf/quick_perf.py
+++ b/tests/perf/quick_perf.py
@@ -19,7 +19,7 @@
 
 # For use with CMake to run simple performance tests in Proton.
 # Assumes that rector-recv and reactor-send can be found in PATH.
-# CMkake's choice of python executable may be passed via PYTHON_EXE environment var.
+# CMake's choice of python executable may be passed via PYTHON_EXE environment var.
 # Add any OS specific monitor helpers in PN_QPERF_MON: i.e.
 #    PN_QPERF_MON="time taskset 0x2" make quick_perf_c
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/codec.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/codec.py b/tests/python/proton_tests/codec.py
index 49a57e0..27e70cf 100644
--- a/tests/python/proton_tests/codec.py
+++ b/tests/python/proton_tests/codec.py
@@ -272,7 +272,7 @@ class DataTest(Test):
 
   def testFloat(self):
     # we have to use a special comparison here because python
-    # internaly only uses doubles and converting between floats and
+    # internally only uses doubles and converting between floats and
     # doubles is imprecise
     self._test("float", 0, 1, 2, 3, 0.1, 0.2, 0.3, -1, -2, -3, -0.1, -0.2, -0.3,
                eq=lambda x, y: x - y < 0.000001)

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/engine.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/engine.py b/tests/python/proton_tests/engine.py
index 7bb5f78..22b209b 100644
--- a/tests/python/proton_tests/engine.py
+++ b/tests/python/proton_tests/engine.py
@@ -35,7 +35,7 @@ if not hasattr(gc, "garbage"):
 # future test areas
 #  + different permutations of setup
 #   - creating deliveries and calling input/output before opening the session/link
-#  + shrinking output_size down to something small? should the enginge buffer?
+#  + shrinking output_size down to something small? should the engine buffer?
 #  + resuming
 #    - locally and remotely created deliveries with the same tag
 
@@ -1170,7 +1170,7 @@ class MaxFrameTransferTest(Test):
 
   def testBigMessage(self):
     """
-    Test transfering a big message.
+    Test transferring a big message.
     """
     self.snd, self.rcv = self.link("test-link")
     self.c1 = self.snd.session.connection

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/message.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/message.py b/tests/python/proton_tests/message.py
index 2d6e19e..550520e 100644
--- a/tests/python/proton_tests/message.py
+++ b/tests/python/proton_tests/message.py
@@ -69,7 +69,7 @@ class AccessorsTest(Test):
   def testTtl(self):
     self._test("ttl", 0, range(12345, 54321))
 
-  def testFirstAquirer(self):
+  def testFirstAcquirer(self):
     self._test("first_acquirer", False, (True, False))
 
   def testDeliveryCount(self):

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/messenger.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/messenger.py b/tests/python/proton_tests/messenger.py
index 7e08c98..91283ed 100644
--- a/tests/python/proton_tests/messenger.py
+++ b/tests/python/proton_tests/messenger.py
@@ -629,7 +629,7 @@ class MessengerTest(Test):
   def testDefaultRewriteSUPHPN(self):
     self._testRewrite("amqp://user:pass@original:123/name", "amqp://original:123/name")
 
-  def testRewriteSupress(self):
+  def testRewriteSuppress(self):
     self.client.rewrite("*", None)
     self._testRewrite("asdf", None)
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/sasl.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/sasl.py b/tests/python/proton_tests/sasl.py
index c23ef97..e916229 100644
--- a/tests/python/proton_tests/sasl.py
+++ b/tests/python/proton_tests/sasl.py
@@ -27,7 +27,7 @@ from .common import pump, Skipped
 from proton._compat import str2bin
 
 def _sslCertpath(file):
-    """ Return the full path to the certificate,keyfile, etc.
+    """ Return the full path to the certificate, keyfile, etc.
     """
     if os.name=="nt":
         if file.find("private-key")!=-1:
@@ -353,7 +353,7 @@ class SASLMechTest(Test):
     _testSaslMech(self, 'PLAIN')
 
 # SCRAM not supported before Cyrus SASL 2.1.26
-# so not universal and hance need a test for support
+# so not universal and hence need a test for support
 # to keep it in tests.
 #  def testSCRAMSHA1(self):
 #    common.ensureCanTestExtendedSASL()

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/python/proton_tests/ssl.py
----------------------------------------------------------------------
diff --git a/tests/python/proton_tests/ssl.py b/tests/python/proton_tests/ssl.py
index a8fe837..1cada89 100644
--- a/tests/python/proton_tests/ssl.py
+++ b/tests/python/proton_tests/ssl.py
@@ -571,7 +571,7 @@ class SslTest(common.Test):
         self._pump( client, server )
 
     def test_multiple_sessions(self):
-        """ Test multiple simultaineous active SSL sessions with bi-directional
+        """ Test multiple simultaneous active SSL sessions with bi-directional
         certificate verification, shared across two domains.
         """
         self.server_domain.set_credentials(self._testpath("server-certificate.pem"),
@@ -789,7 +789,7 @@ class SslTest(common.Test):
         self.tearDown()
 
         # Pass: ensure that the hostname supplied by the connection is used if
-        # none has been specified for the SSL instanace
+        # none has been specified for the SSL instance
         self.setUp()
         self.server_domain.set_credentials(self._testpath("server-certificate.pem"),
                                     self._testpath("server-private-key.pem"),

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tests/tools/apps/c/reactor-recv.c
----------------------------------------------------------------------
diff --git a/tests/tools/apps/c/reactor-recv.c b/tests/tools/apps/c/reactor-recv.c
index bdd1cc2..2a3d434 100644
--- a/tests/tools/apps/c/reactor-recv.c
+++ b/tests/tools/apps/c/reactor-recv.c
@@ -154,7 +154,7 @@ void connection_dispatch(pn_handler_t *h, pn_event_t *event, pn_event_type_t typ
     {
       pn_link_t *link = pn_event_link(event);
       if (pn_link_is_receiver(link)) {
-        check(cc->recv_link == NULL, "Multiple incomming links on one connection");
+        check(cc->recv_link == NULL, "Multiple incoming links on one connection");
         cc->recv_link = link;
         pn_connection_t *conn = pn_event_connection(event);
         pn_list_add(cc->global->active_connections, conn);
@@ -337,7 +337,7 @@ void listener_dispatch(pn_handler_t *h, pn_event_t *event, pn_event_type_t type)
     break;
   case PN_REACTOR_QUIESCED:
     {
-      // Two quiesce in a row means we have been idle for a timout period
+      // Two quiesce in a row means we have been idle for a timeout period
       if (gc->opts->timeout != -1 && gc->quiesce_count > 1)
         global_shutdown(gc);
     }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tools/check_abi/README.md
----------------------------------------------------------------------
diff --git a/tools/check_abi/README.md b/tools/check_abi/README.md
index d9865c3..efe9eaf 100644
--- a/tools/check_abi/README.md
+++ b/tools/check_abi/README.md
@@ -1,7 +1,7 @@
 This is a tool for looking at the ELF symbols exported by a C/C++ shared library.
 
 Currently it has some rough edges, but it will take a file of expected symbols and
-tell you the difference from what is ewxpected.
+tell you the difference from what is expected.
 
 Currently you also need to compile the C++ programs in the same directory to support the script
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tools/cmake/Modules/WindowsC99SymbolCheck.py
----------------------------------------------------------------------
diff --git a/tools/cmake/Modules/WindowsC99SymbolCheck.py b/tools/cmake/Modules/WindowsC99SymbolCheck.py
index 7c2c9f2..dd1f8f9 100644
--- a/tools/cmake/Modules/WindowsC99SymbolCheck.py
+++ b/tools/cmake/Modules/WindowsC99SymbolCheck.py
@@ -19,7 +19,7 @@
 
 #
 # Stop cmake build if pn_i_xxx substitute functions aren't used for
-# the dangererous non-complying [v]snprintf family.  A source of
+# the dangerous non-complying [v]snprintf family.  A source of
 # painful bug-hunting.
 #
 # Each obj must be checked instead of just the dll since Visual Studio

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/tools/py/proctest.py
----------------------------------------------------------------------
diff --git a/tools/py/proctest.py b/tools/py/proctest.py
index 35eb216..d779573 100644
--- a/tools/py/proctest.py
+++ b/tools/py/proctest.py
@@ -41,7 +41,7 @@ class TestPort(object):
     def __init__(self):
         self.sock = socket.socket(socket.AF_INET, socket.SOCK_STREAM)
         self.sock.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)
-        self.sock.bind(('127.0.0.1', 0)) # Testing exampless is local only
+        self.sock.bind(('127.0.0.1', 0)) # Testing examples is local only
         self.host, self.port = socket.getnameinfo(self.sock.getsockname(), 0)
         self.addr = "%s:%s" % (self.host, self.port)
 


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


[4/4] qpid-proton git commit: PROTON-1517: For broader compatibility, use a string correlation ID

Posted by jr...@apache.org.
PROTON-1517: For broader compatibility, use a string correlation ID


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

Branch: refs/heads/master
Commit: 2b033949c54549591113e61ea33e625f9b898cbb
Parents: e22ca53
Author: Justin Ross <jr...@apache.org>
Authored: Fri Dec 8 13:03:07 2017 -0800
Committer: Justin Ross <jr...@apache.org>
Committed: Fri Dec 8 13:03:07 2017 -0800

----------------------------------------------------------------------
 proton-c/bindings/python/proton/utils.py | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/2b033949/proton-c/bindings/python/proton/utils.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/utils.py b/proton-c/bindings/python/proton/utils.py
index cf36bbe..1d052d0 100644
--- a/proton-c/bindings/python/proton/utils.py
+++ b/proton-c/bindings/python/proton/utils.py
@@ -372,7 +372,7 @@ class SyncRequestResponse(IncomingMessageHandler):
         if not self.address and not request.address:
             raise ValueError("Request message has no address: %s" % request)
         request.reply_to = self.reply_to
-        request.correlation_id = correlation_id = self.correlation_id.next()
+        request.correlation_id = correlation_id = str(self.correlation_id.next())
         self.sender.send(request)
         def wakeup():
             return self.response and (self.response.correlation_id == correlation_id)


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


[2/4] qpid-proton git commit: PROTON-1651: Fix typos found by way of spell check (Thanks, Jiri)

Posted by jr...@apache.org.
PROTON-1651: Fix typos found by way of spell check (Thanks, Jiri)


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

Branch: refs/heads/master
Commit: e22ca536c69e840bbe9816029a5903408c9a2570
Parents: 5c746ce
Author: Justin Ross <jr...@apache.org>
Authored: Fri Dec 8 12:48:35 2017 -0800
Committer: Justin Ross <jr...@apache.org>
Committed: Fri Dec 8 12:59:19 2017 -0800

----------------------------------------------------------------------
 bin/record-coverage.sh                          |  2 +-
 docs/markdown/index.md                          |  2 +-
 docs/markdown/messenger/message-disposition.md  |  2 +-
 examples/c/direct.c                             |  2 +-
 examples/c/example_test.py                      |  2 +-
 examples/c/send-abort.c                         |  2 +-
 examples/c/send-ssl.c                           |  2 +-
 examples/c/send.c                               |  2 +-
 examples/cpp/README.dox                         |  2 +-
 examples/cpp/encode_decode.cpp                  |  2 +-
 examples/cpp/example_test.py                    |  2 +-
 examples/cpp/flow_control.cpp                   |  2 +-
 examples/cpp/multithreaded_client.cpp           |  4 +--
 .../cpp/multithreaded_client_flow_control.cpp   |  4 +--
 examples/cpp/ssl_client_cert.cpp                |  2 +-
 examples/cpp/tutorial.dox                       |  2 +-
 examples/go/README.md                           |  2 +-
 examples/go/electron/broker.go                  |  2 +-
 examples/go/electron/send.go                    |  2 +-
 examples/go/proton/broker.go                    |  4 +--
 examples/python/README                          |  4 +--
 examples/python/sync_client.py                  |  2 +-
 .../bindings/cpp/include/proton/container.hpp   |  2 +-
 .../bindings/cpp/include/proton/message.hpp     |  2 +-
 .../cpp/include/proton/source_options.hpp       |  2 +-
 .../bindings/cpp/include/proton/tracker.hpp     |  4 +--
 proton-c/bindings/cpp/include/proton/uuid.hpp   |  4 +--
 proton-c/bindings/cpp/src/interop_test.cpp      |  6 ++---
 proton-c/bindings/cpp/src/messaging_adapter.cpp |  4 +--
 .../cpp/src/proactor_container_impl.cpp         |  6 ++---
 proton-c/bindings/cpp/src/test_port.hpp         |  2 +-
 proton-c/bindings/cpp/src/uuid.cpp              |  2 +-
 proton-c/bindings/go/genwrap.go                 |  2 +-
 .../bindings/go/src/qpid.apache.org/README.md   |  2 +-
 .../go/src/qpid.apache.org/amqp/message.go      |  4 +--
 .../go/src/qpid.apache.org/amqp/types.go        |  2 +-
 .../go/src/qpid.apache.org/amqp/types_test.go   | 26 ++++++++++----------
 .../go/src/qpid.apache.org/amqp/url_test.go     |  2 +-
 .../src/qpid.apache.org/electron/connection.go  |  2 +-
 .../qpid.apache.org/electron/electron_test.go   |  2 +-
 .../go/src/qpid.apache.org/electron/receiver.go |  2 +-
 .../go/src/qpid.apache.org/electron/time.go     |  2 +-
 .../go/src/qpid.apache.org/proton/engine.go     |  6 ++---
 .../go/src/qpid.apache.org/proton/handlers.go   |  2 +-
 .../go/src/qpid.apache.org/proton/message.go    |  4 +--
 .../go/src/qpid.apache.org/proton/wrappers.go   |  4 +--
 proton-c/bindings/javascript/README             | 10 ++++----
 proton-c/bindings/javascript/data-uuid.js       |  6 ++---
 proton-c/bindings/javascript/data.js            | 14 +++++------
 proton-c/bindings/javascript/message.js         |  6 ++---
 proton-c/bindings/javascript/messenger.js       |  6 ++---
 proton-c/bindings/javascript/module.js          |  2 +-
 proton-c/bindings/perl/lib/qpid/proton/Data.pm  |  6 ++---
 proton-c/bindings/perl/tests/hash_helper.t      |  2 +-
 proton-c/bindings/perl/tests/message.t          |  4 +--
 proton-c/bindings/python/docs/overview.rst      |  4 +--
 proton-c/bindings/python/docs/tutorial.rst      |  4 +--
 proton-c/bindings/python/proton/__init__.py     | 12 ++++-----
 proton-c/bindings/python/proton/handlers.py     |  8 +++---
 proton-c/bindings/python/proton/reactor.py      | 12 ++++-----
 proton-c/bindings/python/proton/utils.py        |  4 +--
 proton-c/bindings/python/setup.py.in            |  2 +-
 proton-c/include/proton/codec.h                 | 14 +++++------
 proton-c/include/proton/connection.h            | 14 +++++------
 proton-c/include/proton/connection_driver.h     |  4 +--
 proton-c/include/proton/delivery.h              |  4 +--
 proton-c/include/proton/event.h                 |  4 +--
 proton-c/include/proton/link.h                  |  2 +-
 proton-c/include/proton/log.h                   |  4 +--
 proton-c/include/proton/message.h               |  4 +--
 proton-c/include/proton/messenger.h             | 10 ++++----
 proton-c/include/proton/reactor.h               |  2 +-
 proton-c/include/proton/sasl.h                  |  2 +-
 proton-c/include/proton/selectable.h            |  4 +--
 proton-c/include/proton/terminus.h              |  2 +-
 proton-c/include/proton/transport.h             | 14 +++++------
 proton-c/include/proton/type_compat.h           |  2 +-
 proton-c/mllib/dom.py                           |  2 +-
 proton-c/src/core/transport.c                   |  2 +-
 proton-c/src/libqpid-proton-proactor.pc.in      |  2 +-
 proton-c/src/proactor/epoll.c                   |  6 ++---
 proton-c/src/proactor/libuv.c                   |  2 +-
 proton-c/src/proactor/win_iocp.c                |  4 +--
 proton-c/src/reactor/connection.c               |  2 +-
 proton-c/src/sasl/sasl.c                        |  2 +-
 proton-c/src/ssl/schannel.c                     |  4 +--
 proton-c/src/tests/proactor.c                   |  8 +++---
 proton-c/src/tests/refcount.c                   |  2 +-
 proton-c/src/tests/test_port.h                  |  2 +-
 proton-c/src/tests/test_tools.h                 |  2 +-
 tests/javascript/codec.js                       |  2 +-
 tests/javascript/message.js                     |  4 +--
 tests/perf/README.txt                           |  2 +-
 tests/perf/quick_perf.py                        |  2 +-
 tests/python/proton_tests/codec.py              |  2 +-
 tests/python/proton_tests/engine.py             |  4 +--
 tests/python/proton_tests/message.py            |  2 +-
 tests/python/proton_tests/messenger.py          |  2 +-
 tests/python/proton_tests/sasl.py               |  4 +--
 tests/python/proton_tests/ssl.py                |  4 +--
 tests/tools/apps/c/reactor-recv.c               |  4 +--
 tools/check_abi/README.md                       |  2 +-
 tools/cmake/Modules/WindowsC99SymbolCheck.py    |  2 +-
 tools/py/proctest.py                            |  2 +-
 104 files changed, 207 insertions(+), 207 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/bin/record-coverage.sh
----------------------------------------------------------------------
diff --git a/bin/record-coverage.sh b/bin/record-coverage.sh
index f161e6d..3d1aa1d 100755
--- a/bin/record-coverage.sh
+++ b/bin/record-coverage.sh
@@ -12,7 +12,7 @@
 # - The second is the build tree: this is optional and if not specified is assumed to be the
 #   current directory.
 #
-# The output is in the form of an html report which will be found in the generated html direectory.
+# The output is in the form of an html report which will be found in the generated html directory.
 # - There will also be a number of intermediate files left in the current directory.
 #
 # The typical way to use it would be to use the "Coverage" build type to get instrumented

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/docs/markdown/index.md
----------------------------------------------------------------------
diff --git a/docs/markdown/index.md b/docs/markdown/index.md
index 5262c44..0f0a8e3 100644
--- a/docs/markdown/index.md
+++ b/docs/markdown/index.md
@@ -18,7 +18,7 @@ globally federated topologies
 
 Proton is multi-lingual:
 
-- Proton-C - a C implementation with lanuage bindings in Python, Php, Perl,
+- Proton-C - a C implementation with language bindings in Python, Php, Perl,
 Ruby, and Java (via JNI).
 - Proton-J - a pure Java implementation
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/docs/markdown/messenger/message-disposition.md
----------------------------------------------------------------------
diff --git a/docs/markdown/messenger/message-disposition.md b/docs/markdown/messenger/message-disposition.md
index bf66d2e..70d551f 100644
--- a/docs/markdown/messenger/message-disposition.md
+++ b/docs/markdown/messenger/message-disposition.md
@@ -58,7 +58,7 @@ must set a positive size for its incoming window:
 
         pn_messenger_set_incoming_window(messenger, N);
 
-You can implicity accept messages by simply letting enough
+You can implicitly accept messages by simply letting enough
 new messages arrive.  As older messages pass beyond the threshold
 of your incoming window size, they will be automatically
 accepted.  Thus, if you want to automatically accept all

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/c/direct.c
----------------------------------------------------------------------
diff --git a/examples/c/direct.c b/examples/c/direct.c
index 219cd60..104a4a1 100644
--- a/examples/c/direct.c
+++ b/examples/c/direct.c
@@ -207,7 +207,7 @@ static void handle_send(app_data_t* app, pn_event_t* event) {
    }
 
    case PN_DELIVERY: {
-     /* We received acknowledgedment from the peer that a message was delivered. */
+     /* We received acknowledgement from the peer that a message was delivered. */
      pn_delivery_t* d = pn_event_delivery(event);
      if (pn_delivery_remote_state(d) == PN_ACCEPTED) {
        if (++app->acknowledged == app->message_count) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/c/example_test.py
----------------------------------------------------------------------
diff --git a/examples/c/example_test.py b/examples/c/example_test.py
index 5c97e46..782728e 100644
--- a/examples/c/example_test.py
+++ b/examples/c/example_test.py
@@ -58,7 +58,7 @@ class Broker(object):
 class CExampleTest(ProcTestCase):
 
     def runex(self, name, port, messages=MESSAGES):
-        """Run an example with standard arugments, return output"""
+        """Run an example with standard arguments, return output"""
         return self.proc([name, "", str(port), "xtest", str(messages)]).wait_exit()
 
     def test_send_receive(self):

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/c/send-abort.c
----------------------------------------------------------------------
diff --git a/examples/c/send-abort.c b/examples/c/send-abort.c
index defbee5..2894ebe 100644
--- a/examples/c/send-abort.c
+++ b/examples/c/send-abort.c
@@ -156,7 +156,7 @@ static bool handle(app_data_t* app, pn_event_t* event) {
    }
 
    case PN_DELIVERY: {
-     /* We received acknowledgedment from the peer that a message was delivered. */
+     /* We received acknowledgement from the peer that a message was delivered. */
      pn_delivery_t* d = pn_event_delivery(event);
      fprintf(stderr, "Aborted deliveries should not receive delivery events. Delivery state %d\n", (int)pn_delivery_remote_state(d));
      pn_connection_close(pn_event_connection(event));

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/c/send-ssl.c
----------------------------------------------------------------------
diff --git a/examples/c/send-ssl.c b/examples/c/send-ssl.c
index 4fc80c3..e307fa4 100644
--- a/examples/c/send-ssl.c
+++ b/examples/c/send-ssl.c
@@ -149,7 +149,7 @@ static bool handle(app_data_t* app, pn_event_t* event) {
    }
 
    case PN_DELIVERY: {
-     /* We received acknowledgedment from the peer that a message was delivered. */
+     /* We received acknowledgement from the peer that a message was delivered. */
      pn_delivery_t* d = pn_event_delivery(event);
      if (pn_delivery_remote_state(d) == PN_ACCEPTED) {
        if (++app->acknowledged == app->message_count) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/c/send.c
----------------------------------------------------------------------
diff --git a/examples/c/send.c b/examples/c/send.c
index 1af74f8..2f48877 100644
--- a/examples/c/send.c
+++ b/examples/c/send.c
@@ -126,7 +126,7 @@ static bool handle(app_data_t* app, pn_event_t* event) {
    }
 
    case PN_DELIVERY: {
-     /* We received acknowledgedment from the peer that a message was delivered. */
+     /* We received acknowledgement from the peer that a message was delivered. */
      pn_delivery_t* d = pn_event_delivery(event);
      if (pn_delivery_remote_state(d) == PN_ACCEPTED) {
        if (++app->acknowledged == app->message_count) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/README.dox
----------------------------------------------------------------------
diff --git a/examples/cpp/README.dox b/examples/cpp/README.dox
index b475b2a..a5228d3 100644
--- a/examples/cpp/README.dox
+++ b/examples/cpp/README.dox
@@ -103,7 +103,7 @@ alternatives.
 /** @example broker.cpp
 
 A broker using the `proton::container`. You can use this to run other examples
-that reqiure an intermediary, or you can use any AMQP 1.0 broker. This broker
+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.
 
 */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/encode_decode.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/encode_decode.cpp b/examples/cpp/encode_decode.cpp
index 862d1dd..cd6169a 100644
--- a/examples/cpp/encode_decode.cpp
+++ b/examples/cpp/encode_decode.cpp
@@ -175,7 +175,7 @@ int main(int, char**) {
 
 // print_next prints the next value from values by recursively descending into complex values.
 //
-// NOTE this is for example puroses only: There is a built in ostream operator<< for values.
+// NOTE this is for example purposes only: There is a built in ostream operator<< for values.
 //
 //
 static void print_next(proton::codec::decoder& d) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/example_test.py
----------------------------------------------------------------------
diff --git a/examples/cpp/example_test.py b/examples/cpp/example_test.py
index 5d8d45f..8be3352 100644
--- a/examples/cpp/example_test.py
+++ b/examples/cpp/example_test.py
@@ -159,7 +159,7 @@ class ContainerExampleTest(BrokerTestCase):
         want="""success: Example 1: simple credit
 success: Example 2: basic drain
 success: Example 3: drain without credit
-success: Exmaple 4: high/low watermark
+success: Example 4: high/low watermark
 """
         with TestPort() as tp:
             self.assertMultiLineEqual(want, self.proc(["flow_control", "--address", tp.addr, "--quiet"]).wait_exit())

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/flow_control.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/flow_control.cpp b/examples/cpp/flow_control.cpp
index 3773454..f27b6f4 100644
--- a/examples/cpp/flow_control.cpp
+++ b/examples/cpp/flow_control.cpp
@@ -163,7 +163,7 @@ class flow_receiver : public proton::messaging_handler {
                 return;
             }
 
-            verify(received == 25 && r.credit() == 0, "Exmaple 4: high/low watermark");
+            verify(received == 25 && r.credit() == 0, "Example 4: high/low watermark");
             r.connection().close();
             break;
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/multithreaded_client.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/multithreaded_client.cpp b/examples/cpp/multithreaded_client.cpp
index c9e6607..78085e2 100644
--- a/examples/cpp/multithreaded_client.cpp
+++ b/examples/cpp/multithreaded_client.cpp
@@ -47,7 +47,7 @@
 #include <string>
 #include <thread>
 
-// Lock output from threads to avoid scramblin
+// Lock output from threads to avoid scrambling
 std::mutex out_lock;
 #define OUT(x) do { std::lock_guard<std::mutex> l(out_lock); x; } while (false)
 
@@ -100,7 +100,7 @@ class client : public proton::messaging_handler {
         return work_queue_;
     }
 
-    // == messaging_handler overrides, only called in proton hander thread
+    // == messaging_handler overrides, only called in proton handler thread
 
     // Note: this example creates a connection when the container starts.
     // To create connections after the container has started, use

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/multithreaded_client_flow_control.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/multithreaded_client_flow_control.cpp b/examples/cpp/multithreaded_client_flow_control.cpp
index 427b9c8..db652f8 100644
--- a/examples/cpp/multithreaded_client_flow_control.cpp
+++ b/examples/cpp/multithreaded_client_flow_control.cpp
@@ -57,7 +57,7 @@
 #include <string>
 #include <thread>
 
-// Lock output from threads to avoid scramblin
+// Lock output from threads to avoid scrambling
 std::mutex out_lock;
 #define OUT(x) do { std::lock_guard<std::mutex> l(out_lock); x; } while (false)
 
@@ -106,7 +106,7 @@ class sender : private proton::messaging_handler {
         return work_queue_;
     }
 
-    // == messaging_handler overrides, only called in proton hander thread
+    // == messaging_handler overrides, only called in proton handler thread
 
     void on_sender_open(proton::sender& s) override {
         // Make sure sender_ and work_queue_ are set atomically

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/ssl_client_cert.cpp
----------------------------------------------------------------------
diff --git a/examples/cpp/ssl_client_cert.cpp b/examples/cpp/ssl_client_cert.cpp
index 96ee122..32a9a1d 100644
--- a/examples/cpp/ssl_client_cert.cpp
+++ b/examples/cpp/ssl_client_cert.cpp
@@ -96,7 +96,7 @@ class hello_world_direct : public proton::messaging_handler {
         // Configure client.
         ssl_certificate client_cert = platform_certificate("tclient", "tclientpw");
         std::string server_CA = platform_CA("tserver");
-        // Since the test certifcate's credentials are unlikely to match this host's name, downgrade the verification
+        // Since the test certificate's credentials are unlikely to match this host's name, downgrade the verification
         // from VERIFY_PEER_NAME to VERIFY_PEER.
         ssl_client_options ssl_cli(client_cert, server_CA, proton::ssl::VERIFY_PEER);
         connection_options client_opts;

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/cpp/tutorial.dox
----------------------------------------------------------------------
diff --git a/examples/cpp/tutorial.dox b/examples/cpp/tutorial.dox
index f49b9e3..0b72d9d 100644
--- a/examples/cpp/tutorial.dox
+++ b/examples/cpp/tutorial.dox
@@ -1,7 +1,7 @@
 // -*-markdown-*-
 // NOTE: doxygen can include markdown pages directly but there seems to be a bug
 // that shows messed-up line numbers in \skip \until code extracts. This file
-// is markdown wrapped in a doxygen comment - which works. The file is best viewed/editied
+// is markdown wrapped in a doxygen comment - which works. The file is best viewed/edited
 // as markdown.
 
 /**

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/go/README.md
----------------------------------------------------------------------
diff --git a/examples/go/README.md b/examples/go/README.md
index eaf6639..e8bb8f5 100644
--- a/examples/go/README.md
+++ b/examples/go/README.md
@@ -118,7 +118,7 @@ messages and the sender link for available credit.
 [electron/broker.go](electron/broker.go) does not need any "upside-down"
 event-driven code, it is implemented as straightforward loops. The broker is a
 loop listening for connections. Each connection is a loop accepting for incoming
-sender or recdiver links. Each receiving link is a loop that receives a message
+sender or receiver links. Each receiving link is a loop that receives a message
 and pushes it to a queue.  Each sending link is a loop that pops a message from
 a queue and sends it.
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/go/electron/broker.go
----------------------------------------------------------------------
diff --git a/examples/go/electron/broker.go b/examples/go/electron/broker.go
index 64d7120..6df4e16 100644
--- a/examples/go/electron/broker.go
+++ b/examples/go/electron/broker.go
@@ -111,7 +111,7 @@ func (b *broker) run() error {
 	}
 }
 
-// State for a broker connectoin
+// State for a broker connection
 type connection struct {
 	broker     *broker
 	connection electron.Connection

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/go/electron/send.go
----------------------------------------------------------------------
diff --git a/examples/go/electron/send.go b/examples/go/electron/send.go
index ac4e367..7e7481d 100644
--- a/examples/go/electron/send.go
+++ b/examples/go/electron/send.go
@@ -64,7 +64,7 @@ func main() {
 	wait.Add(len(urls)) // Wait for one goroutine per URL.
 
 	container := electron.NewContainer(fmt.Sprintf("send[%v]", os.Getpid()))
-	connections := make(chan electron.Connection, len(urls)) // Connctions to close on exit
+	connections := make(chan electron.Connection, len(urls)) // Connections to close on exit
 
 	// Start a goroutine for each URL to send messages.
 	for _, urlStr := range urls {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/go/proton/broker.go
----------------------------------------------------------------------
diff --git a/examples/go/proton/broker.go b/examples/go/proton/broker.go
index 8291ca9..8a243e8 100644
--- a/examples/go/proton/broker.go
+++ b/examples/go/proton/broker.go
@@ -24,7 +24,7 @@ under the License.
 // messages to queues or subscribe to receive messages from them.
 //
 
-// TODO: show how to handle acknowledgedments from receivers and put rejected or
+// TODO: show how to handle acknowledgements from receivers and put rejected or
 // un-acknowledged messages back on their queues.
 
 package main
@@ -44,7 +44,7 @@ import (
 func usage() {
 	fmt.Fprintf(os.Stderr, `
 Usage: %s
-A simple broker-like demo. Queues are created automatically for sender or receiver addrsses.
+A simple broker-like demo. Queues are created automatically for sender or receiver addresses.
 `, os.Args[0])
 	flag.PrintDefaults()
 }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/python/README
----------------------------------------------------------------------
diff --git a/examples/python/README b/examples/python/README
index 9051187..41a6bbd 100644
--- a/examples/python/README
+++ b/examples/python/README
@@ -16,7 +16,7 @@ helloworld.py
 Basic example that connects to an intermediary on localhost:5672,
 establishes a subscription from the 'examples' node on that
 intermediary, then creates a sending link to the same node and sends
-one message. On receving the message back via the subcription, the
+one message. On receiving the message back via the subscription, the
 connection is closed.
 
 helloworld_blocking.py
@@ -79,7 +79,7 @@ db_ctrl.py
 
 A utility for setting up the database tables for the two examples
 above. Takes two arguments, the action to perform and the name of the
-database on which to perfom it. The database used by db_send.py is
+database on which to perform it. The database used by db_send.py is
 src_db, that by db_recv.py is dst_db. The valid actions are 'init',
 which creates the table, 'list' which displays the contents and
 'insert' which inserts records from standard-in and is used to

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/examples/python/sync_client.py
----------------------------------------------------------------------
diff --git a/examples/python/sync_client.py b/examples/python/sync_client.py
index 0b7b045..7b86e29 100755
--- a/examples/python/sync_client.py
+++ b/examples/python/sync_client.py
@@ -20,7 +20,7 @@
 
 """
 Demonstrates the client side of the synchronous request-response pattern
-(also known as RPC or Remote Procecure Call) using proton.
+(also known as RPC or Remote Procedure Call) using proton.
 
 """
 from __future__ import print_function, unicode_literals

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/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 e80acbe..9733f78 100644
--- a/proton-c/bindings/cpp/include/proton/container.hpp
+++ b/proton-c/bindings/cpp/include/proton/container.hpp
@@ -265,7 +265,7 @@ class PN_CPP_CLASS_EXTERN container {
     PN_CPP_EXTERN std::string id() const;
 
     /// Connection options applied to outgoing connections. These are
-    /// applied first and then overriden by any options provided in
+    /// applied first and then overridden by any options provided in
     /// `connect()` or `messaging_handler::on_connection_open()`.
     PN_CPP_EXTERN void client_connection_options(const connection_options& conn_opts);
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/include/proton/message.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/message.hpp b/proton-c/bindings/cpp/include/proton/message.hpp
index 2273076..50e12e4 100644
--- a/proton-c/bindings/cpp/include/proton/message.hpp
+++ b/proton-c/bindings/cpp/include/proton/message.hpp
@@ -302,7 +302,7 @@ class message {
     /// be modified in place.
     PN_CPP_EXTERN annotation_map& message_annotations();
 
-    /// Examine the meessage annotations map.
+    /// Examine the message annotations map.
     PN_CPP_EXTERN const annotation_map& message_annotations() const;
 
     /// Get the delivery annotations map.  It can

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/include/proton/source_options.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/source_options.hpp b/proton-c/bindings/cpp/include/proton/source_options.hpp
index 5b527ad..dd9d9d0 100644
--- a/proton-c/bindings/cpp/include/proton/source_options.hpp
+++ b/proton-c/bindings/cpp/include/proton/source_options.hpp
@@ -63,7 +63,7 @@ class source_options {
     /// ignored.
     PN_CPP_EXTERN source_options& dynamic(bool);
 
-    /// Control whether messsages are browsed or consumed.  The
+    /// Control whether messages are browsed or consumed.  The
     /// default is source::MOVE, meaning consumed.
     PN_CPP_EXTERN source_options& distribution_mode(enum source::distribution_mode);
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/include/proton/tracker.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/tracker.hpp b/proton-c/bindings/cpp/include/proton/tracker.hpp
index b3e6811..8c3a58d 100644
--- a/proton-c/bindings/cpp/include/proton/tracker.hpp
+++ b/proton-c/bindings/cpp/include/proton/tracker.hpp
@@ -49,9 +49,9 @@ class tracker : public transfer {
     /// Get the sender for this tracker.
     PN_CPP_EXTERN class sender sender() const;
 
-    // @cond INTERNAL
+    /// @cond INTERNAL
   friend class internal::factory<tracker>;
-    // @endcond
+    /// @endcond
 };
 
 } // proton

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/include/proton/uuid.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/include/proton/uuid.hpp b/proton-c/bindings/cpp/include/proton/uuid.hpp
index 464d7a7..66578df 100644
--- a/proton-c/bindings/cpp/include/proton/uuid.hpp
+++ b/proton-c/bindings/cpp/include/proton/uuid.hpp
@@ -52,12 +52,12 @@ class uuid : public byte_array<16> {
     PN_CPP_EXTERN static uuid random();
 
     /// UUID standard string format: 8-4-4-4-12 (36 chars, 32
-    /// alphanumeric chars and 4 hypens).
+    /// alphanumeric chars and 4 hyphens).
     PN_CPP_EXTERN std::string str()  const;
 };
 
 /// UUID standard format: 8-4-4-4-12 (36 chars, 32 alphanumeric chars
-/// and 4 hypens).
+/// and 4 hyphens).
 PN_CPP_EXTERN std::ostream& operator<<(std::ostream&, const uuid&);
 
 } // proton

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/src/interop_test.cpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/src/interop_test.cpp b/proton-c/bindings/cpp/src/interop_test.cpp
index de6ae63..a253a37 100644
--- a/proton-c/bindings/cpp/src/interop_test.cpp
+++ b/proton-c/bindings/cpp/src/interop_test.cpp
@@ -57,8 +57,8 @@ void test_data_ostream() {
     ASSERT_EQUAL("true, false, 42, 42, -42, 12345, -12345, 12345, -12345, 0.125, 0.125", str(dt));
 }
 
-// Test extracting to exact AMQP types works corectly, extrating to invalid types fails.
-void test_decoder_primitves_exact() {
+// Test extracting to exact AMQP types works correctly, extracting to invalid types fails.
+void test_decoder_primitives_exact() {
     value dv;
     decoder d(dv);
     d.decode(read("primitives"));
@@ -109,7 +109,7 @@ int main(int argc, char** argv) {
     tests_dir = argv[1];
 
     RUN_TEST(failed, test_data_ostream());
-    RUN_TEST(failed, test_decoder_primitves_exact());
+    RUN_TEST(failed, test_decoder_primitives_exact());
     RUN_TEST(failed, test_encoder_primitives());
     return failed;
 }

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/src/messaging_adapter.cpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/src/messaging_adapter.cpp b/proton-c/bindings/cpp/src/messaging_adapter.cpp
index 2ba053c..dad8dd2 100644
--- a/proton-c/bindings/cpp/src/messaging_adapter.cpp
+++ b/proton-c/bindings/cpp/src/messaging_adapter.cpp
@@ -175,7 +175,7 @@ void on_delivery(messaging_handler& handler, pn_event_t* event) {
     }
 }
 
-bool is_remote_unititialised(pn_state_t state) {
+bool is_remote_uninitialized(pn_state_t state) {
     return state & PN_REMOTE_UNINIT;
 }
 
@@ -275,7 +275,7 @@ void on_transport_closed(messaging_handler& handler, pn_event_t* event) {
     // If the connection isn't open generate on_transport_open event
     // because we didn't generate it yet and the events won't match.
     pn_connection_t *conn = pn_event_connection(event);
-    if (!conn || is_remote_unititialised(pn_connection_state(conn))) {
+    if (!conn || is_remote_uninitialized(pn_connection_state(conn))) {
         handler.on_transport_open(t);
     }
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/src/proactor_container_impl.cpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/src/proactor_container_impl.cpp b/proton-c/bindings/cpp/src/proactor_container_impl.cpp
index a55cdcb..491b69b 100644
--- a/proton-c/bindings/cpp/src/proactor_container_impl.cpp
+++ b/proton-c/bindings/cpp/src/proactor_container_impl.cpp
@@ -198,13 +198,13 @@ pn_connection_t* container::impl::make_connection_lh(
 
 // Takes ownership of pnc
 //
-// NOTE: After the call to start_connecton() pnc is active in a proactor thread,
+// NOTE: After the call to start_connection() pnc is active in a proactor thread,
 // and may even have been freed already. It is undefined to use pnc (or any
 // object belonging to it) except in appropriate handlers.
 //
 // SUBTLE NOTE: There must not be any proton::object wrappers in scope when
-// start_connecton() is called. The wrapper destructor will call pn_decref()
-// after start_connecton() which is undefined!
+// start_connection() is called. The wrapper destructor will call pn_decref()
+// after start_connection() which is undefined!
 //
 void container::impl::start_connection(const url& url, pn_connection_t *pnc) {
     char caddr[PN_MAX_ADDR];

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/src/test_port.hpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/src/test_port.hpp b/proton-c/bindings/cpp/src/test_port.hpp
index 5d2fada..cc592fa 100644
--- a/proton-c/bindings/cpp/src/test_port.hpp
+++ b/proton-c/bindings/cpp/src/test_port.hpp
@@ -150,7 +150,7 @@ class test_port {
 
     std::string url(const std::string& host="") const {
         std::ostringstream url;
-        url << "amp://" << host << ":" << port_;
+        url << "amqp://" << host << ":" << port_;
         return url.str();
     }
 };

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/cpp/src/uuid.cpp
----------------------------------------------------------------------
diff --git a/proton-c/bindings/cpp/src/uuid.cpp b/proton-c/bindings/cpp/src/uuid.cpp
index 7e0af2c..861d707 100644
--- a/proton-c/bindings/cpp/src/uuid.cpp
+++ b/proton-c/bindings/cpp/src/uuid.cpp
@@ -85,7 +85,7 @@ uuid uuid::random() {
     return bytes;
 }
 
-/// UUID standard format: 8-4-4-4-12 (36 chars, 32 alphanumeric and 4 hypens)
+/// UUID standard format: 8-4-4-4-12 (36 chars, 32 alphanumeric and 4 hyphens)
 std::ostream& operator<<(std::ostream& o, const uuid& u) {
     ios_guard restore_flags(o);
     o << std::hex << std::setfill('0');

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/genwrap.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/genwrap.go b/proton-c/bindings/go/genwrap.go
index 0bf13fa..45b5066 100644
--- a/proton-c/bindings/go/genwrap.go
+++ b/proton-c/bindings/go/genwrap.go
@@ -267,7 +267,7 @@ var (
 func event(out io.Writer) {
 	event_h := readHeader("event")
 
-	// Event is implented by hand in wrappers.go
+	// Event is implemented by hand in wrappers.go
 
 	// Get all the pn_event_type_t enum values
 	var etypes []eventType

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/README.md
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/README.md b/proton-c/bindings/go/src/qpid.apache.org/README.md
index 0977787..5292454 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/README.md
+++ b/proton-c/bindings/go/src/qpid.apache.org/README.md
@@ -6,7 +6,7 @@ available at: <http://godoc.org/?q=qpid.apache.org>
 
 They require the
 [proton-C library and header files](http://qpid.apache.org/proton) to be
-installed.  On many platforms it is avaialable pre-packaged, for example on
+installed.  On many platforms it is available pre-packaged, for example on
 Fedora
 
     dnf install qpid-proton-c-devel

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/amqp/message.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/amqp/message.go b/proton-c/bindings/go/src/qpid.apache.org/amqp/message.go
index 0e13cb9..389fa37 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/amqp/message.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/amqp/message.go
@@ -99,7 +99,7 @@ type Message interface {
 	ContentEncoding() string
 	SetContentEncoding(string)
 
-	// ExpiryTime indicates an absoulte time when the message may be dropped.
+	// ExpiryTime indicates an absolute time when the message may be dropped.
 	// A Zero time (i.e. t.isZero() == true) indicates a message never expires.
 	ExpiryTime() time.Time
 	SetExpiryTime(time.Time)
@@ -146,7 +146,7 @@ type Message interface {
 	// Unmarshal the message body into the value pointed to by v. See amqp.Unmarshal() for details.
 	Unmarshal(interface{})
 
-	// Body value resulting from the default unmarshalling of message body as interface{}
+	// Body value resulting from the default unmarshaling of message body as interface{}
 	Body() interface{}
 
 	// Encode encodes the message as AMQP data. If buffer is non-nil and is large enough

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/amqp/types.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/amqp/types.go b/proton-c/bindings/go/src/qpid.apache.org/amqp/types.go
index 29cf866..a1fe2ac 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/amqp/types.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/amqp/types.go
@@ -165,7 +165,7 @@ func (l List) GoString() string {
 // pnTime converts Go time.Time to Proton millisecond Unix time.
 func pnTime(t time.Time) C.pn_timestamp_t {
 	secs := t.Unix()
-	// Note: sub-second accuracy is not guaraunteed if the Unix time in
+	// Note: sub-second accuracy is not guaranteed if the Unix time in
 	// nanoseconds cannot be represented by an int64 (sometime around year 2260)
 	msecs := (t.UnixNano() % int64(time.Second)) / int64(time.Millisecond)
 	return C.pn_timestamp_t(secs*1000 + msecs)

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/amqp/types_test.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/amqp/types_test.go b/proton-c/bindings/go/src/qpid.apache.org/amqp/types_test.go
index e79ea1b..efa6e59 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/amqp/types_test.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/amqp/types_test.go
@@ -33,13 +33,13 @@ func checkEqual(want interface{}, got interface{}) error {
 	return nil
 }
 
-func checkUnmarshal(marshalled []byte, v interface{}) error {
-	got, err := Unmarshal(marshalled, v)
+func checkUnmarshal(marshaled []byte, v interface{}) error {
+	got, err := Unmarshal(marshaled, v)
 	if err != nil {
 		return err
 	}
-	if got != len(marshalled) {
-		return fmt.Errorf("Wanted to Unmarshal %v bytes, got %v", len(marshalled), got)
+	if got != len(marshaled) {
+		return fmt.Errorf("Wanted to Unmarshal %v bytes, got %v", len(marshaled), got)
 	}
 	return nil
 }
@@ -139,7 +139,7 @@ func TestTypesRoundTrip(t *testing.T) {
 // Round trip from T to T where T is the type of the value.
 func TestTypesRoundTripAll(t *testing.T) {
 	for _, x := range allValues {
-		marshalled, err := Marshal(x, nil)
+		marshaled, err := Marshal(x, nil)
 		if err != nil {
 			t.Error(err)
 		}
@@ -147,7 +147,7 @@ func TestTypesRoundTripAll(t *testing.T) {
 			continue
 		}
 		vp := reflect.New(reflect.TypeOf(x)) // v points to a Zero of the same type as x
-		if err := checkUnmarshal(marshalled, vp.Interface()); err != nil {
+		if err := checkUnmarshal(marshaled, vp.Interface()); err != nil {
 			t.Error(err)
 		}
 		v := vp.Elem().Interface()
@@ -168,11 +168,11 @@ func TestTypesPrint(t *testing.T) {
 
 func TestDescribed(t *testing.T) {
 	want := Described{"D", "V"}
-	marshalled, _ := Marshal(want, nil)
+	marshaled, _ := Marshal(want, nil)
 
 	// Unmarshal to Described type
 	var d Described
-	if err := checkUnmarshal(marshalled, &d); err != nil {
+	if err := checkUnmarshal(marshaled, &d); err != nil {
 		t.Error(err)
 	}
 	if err := checkEqual(want, d); err != nil {
@@ -181,7 +181,7 @@ func TestDescribed(t *testing.T) {
 
 	// Unmarshal to interface{}
 	var i interface{}
-	if err := checkUnmarshal(marshalled, &i); err != nil {
+	if err := checkUnmarshal(marshaled, &i); err != nil {
 		t.Error(err)
 	}
 	if _, ok := i.(Described); !ok {
@@ -193,7 +193,7 @@ func TestDescribed(t *testing.T) {
 
 	// Unmarshal value only (drop descriptor) to the value type
 	var s string
-	if err := checkUnmarshal(marshalled, &s); err != nil {
+	if err := checkUnmarshal(marshaled, &s); err != nil {
 		t.Error(err)
 	}
 	if err := checkEqual(want.Value, s); err != nil {
@@ -202,15 +202,15 @@ func TestDescribed(t *testing.T) {
 
 	// Nested described types
 	want = Described{Described{int64(123), true}, "foo"}
-	marshalled, _ = Marshal(want, nil)
-	if err := checkUnmarshal(marshalled, &d); err != nil {
+	marshaled, _ = Marshal(want, nil)
+	if err := checkUnmarshal(marshaled, &d); err != nil {
 		t.Error(err)
 	}
 	if err := checkEqual(want, d); err != nil {
 		t.Error(err)
 	}
 	// Nested to interface
-	if err := checkUnmarshal(marshalled, &i); err != nil {
+	if err := checkUnmarshal(marshaled, &i); err != nil {
 		t.Error(err)
 	}
 	if err := checkEqual(want, i); err != nil {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/amqp/url_test.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/amqp/url_test.go b/proton-c/bindings/go/src/qpid.apache.org/amqp/url_test.go
index f52d4bf..192e2fb 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/amqp/url_test.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/amqp/url_test.go
@@ -33,7 +33,7 @@ func ExampleParseURL() {
 		"/path",
 		"",
 		":1234",
-                // Taken out becasue the go 1.4 URL parser isn't the same as later
+                // Taken out because the go 1.4 URL parser isn't the same as later
 		//"[::1]",
 		//"[::1",
 		// Output would be:

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/electron/connection.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/electron/connection.go b/proton-c/bindings/go/src/qpid.apache.org/electron/connection.go
index 2749b2b..731e64d 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/electron/connection.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/electron/connection.go
@@ -130,7 +130,7 @@ func VirtualHost(virtualHost string) ConnectionOption {
 // connection.  Only applies to outbound client connection.
 //
 // The connection will erase its copy of the password from memory as soon as it
-// has been used to authenticate. If you are concerned about paswords staying in
+// has been used to authenticate. If you are concerned about passwords staying in
 // memory you should never store them as strings, and should overwrite your
 // copy as soon as you are done with it.
 //

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/electron/electron_test.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/electron/electron_test.go b/proton-c/bindings/go/src/qpid.apache.org/electron/electron_test.go
index d8862b9..74759f5 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/electron/electron_test.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/electron/electron_test.go
@@ -151,7 +151,7 @@ func TestClientSendServerReceive(t *testing.T) {
 				}
 			}()
 
-			// Server recieve
+			// Server receive
 			rm, err := r[i].Receive()
 			if err != nil {
 				t.Fatal(err)

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/electron/receiver.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/electron/receiver.go b/proton-c/bindings/go/src/qpid.apache.org/electron/receiver.go
index 781fd7c..26b46a8 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/electron/receiver.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/electron/receiver.go
@@ -91,7 +91,7 @@ func newReceiver(ls linkSettings) *receiver {
 	return r
 }
 
-// Call in proton gorotine. Max additional credit we can request.
+// Call in proton goroutine. Max additional credit we can request.
 func (r *receiver) maxFlow() int { return cap(r.buffer) - len(r.buffer) - r.pLink.Credit() }
 
 func (r *receiver) flow(credit int) {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/electron/time.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/electron/time.go b/proton-c/bindings/go/src/qpid.apache.org/electron/time.go
index 51bfbc5..52f0cee 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/electron/time.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/electron/time.go
@@ -33,7 +33,7 @@ import (
 // If timeout > 0 and there is no result available before the timeout, they
 // return a zero or nil value and Timeout as an error.
 //
-// If timeout == 0 they will return a result if one is immediatley available or
+// If timeout == 0 they will return a result if one is immediately available or
 // nil/zero and Timeout as an error if not.
 //
 // If timeout == Forever the function will return only when there is a result or

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/proton/engine.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/proton/engine.go b/proton-c/bindings/go/src/qpid.apache.org/proton/engine.go
index c0f0093..d28a09f 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/proton/engine.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/proton/engine.go
@@ -89,7 +89,7 @@ type Injecter interface {
 // invalid. The handler methods will tell you when a value is no longer valid. For
 // example after a LinkClosed event, that link is no longer valid. If you do
 // Link.Close() yourself (in a handler or injected function) the link remains valid
-// until the corresponing LinkClosed event is received by the handler.
+// until the corresponding LinkClosed event is received by the handler.
 //
 // Engine.Close() will take care of cleaning up any remaining values when you are
 // done with the Engine. All values associated with a engine become invalid when you
@@ -217,7 +217,7 @@ func (eng *Engine) InjectWait(f func() error) error {
 }
 
 // Server puts the Engine in server mode, meaning it will auto-detect security settings on
-// the incoming connnection such as use of SASL and SSL.
+// the incoming connection such as use of SASL and SSL.
 // Must be called before Run()
 //
 func (eng *Engine) Server() { eng.Transport().SetServer() }
@@ -319,7 +319,7 @@ func (eng *Engine) Run() error {
 	eng.tick() // Start ticking if needed
 
 	// Channels for read and write buffers going in and out of the read/write goroutines.
-	// The channels are unbuffered: we want to exchange buffers in seuquence.
+	// The channels are unbuffered: we want to exchange buffers in sequence.
 	readsIn, writesIn := make(chan []byte), make(chan []byte)
 	readsOut, writesOut := make(chan []byte), make(chan []byte)
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/proton/handlers.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/proton/handlers.go b/proton-c/bindings/go/src/qpid.apache.org/proton/handlers.go
index 961136e..f101548 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/proton/handlers.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/proton/handlers.go
@@ -244,7 +244,7 @@ func (d flowcontroller) HandleEvent(e Event) {
 	}
 }
 
-// MessagingAdapter implments a EventHandler and delegates to a MessagingHandler.
+// MessagingAdapter implements a EventHandler and delegates to a MessagingHandler.
 // You can modify the exported fields before you pass the MessagingAdapter to
 // a Engine.
 type MessagingAdapter struct {

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/proton/message.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/proton/message.go b/proton-c/bindings/go/src/qpid.apache.org/proton/message.go
index 2336483..fbb1d48 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/proton/message.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/proton/message.go
@@ -35,7 +35,7 @@ import (
 // Equivalent to !d.isNil && d.Readable() && !d.Partial()
 func (d Delivery) HasMessage() bool { return !d.IsNil() && d.Readable() && !d.Partial() }
 
-// Message decodes the message containined in a delivery.
+// Message decodes the message contained in a delivery.
 //
 // Must be called in the correct link context with this delivery as the current message,
 // handling an MMessage event is always a safe context to call this function.
@@ -75,7 +75,7 @@ func (link Link) Send(m amqp.Message) (Delivery, error) {
 	delivery := link.Delivery(nextTag())
 	bytes, err := m.Encode(nil)
 	if err != nil {
-		return Delivery{}, fmt.Errorf("cannot send mesage %s", err)
+		return Delivery{}, fmt.Errorf("cannot send message %s", err)
 	}
 	result := link.SendBytes(bytes)
 	link.Advance()

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/go/src/qpid.apache.org/proton/wrappers.go
----------------------------------------------------------------------
diff --git a/proton-c/bindings/go/src/qpid.apache.org/proton/wrappers.go b/proton-c/bindings/go/src/qpid.apache.org/proton/wrappers.go
index 09f3e65..a7b7fb2 100644
--- a/proton-c/bindings/go/src/qpid.apache.org/proton/wrappers.go
+++ b/proton-c/bindings/go/src/qpid.apache.org/proton/wrappers.go
@@ -168,10 +168,10 @@ func (s State) RemoteUninit() bool { return s.Has(SRemoteUninit) }
 func (s State) RemoteActive() bool { return s.Has(SRemoteActive) }
 func (s State) RemoteClosed() bool { return s.Has(SRemoteClosed) }
 
-// Return a State containig just the local flags
+// Return a State containing just the local flags
 func (s State) Local() State { return State(s & C.PN_LOCAL_MASK) }
 
-// Return a State containig just the remote flags
+// Return a State containing just the remote flags
 func (s State) Remote() State { return State(s & C.PN_REMOTE_MASK) }
 
 // Endpoint is the common interface for Connection, Link and Session.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/README
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/README b/proton-c/bindings/javascript/README
index 2dea949..9ec37d0 100644
--- a/proton-c/bindings/javascript/README
+++ b/proton-c/bindings/javascript/README
@@ -269,7 +269,7 @@ illustrates how to do asynchronous request/response based applications.
 Aside from the asynchronous aspects the rest of the API is essentially the same
 as the Python binding aside from minor things such as camel casing method names etc.
 
-Serialisation/Deserialisation, Types etc.
+Serialisation/Deserialization, Types etc.
 =========================================
 
 The JavaScript binding tries to be as simple, intuitive and natural as possible
@@ -358,7 +358,7 @@ message.body = ['Rod', 'Jane', 'Freddy', {cat: true, donkey: 'hee haw'}];
 // attempt to use the correct type such that message.body = 2147483647; would be
 // sent as an AMQP integer, but because of the way JavaScript coerces integers
 // message.body = 2147483647.0; would also be sent as an AMQP integer because
-// 2147483647.0 gets transparently conveted to 2147483647 by the interpreter, so
+// 2147483647.0 gets transparently converted to 2147483647 by the interpreter, so
 // to explicitly send this as an AMQP float we'd need to do:
 // message.body = 2147483647.0.float();
 
@@ -398,15 +398,15 @@ JSON
 ====
 
 As well as allowing native JavaScript Objects and Arrays to be transparently
-serialised and deserialised via the AMQP type system it is also possible to
-serialise/deserialise as JSON.
+serialised and deserialized via the AMQP type system it is also possible to
+serialise/deserialize as JSON.
 
 message.setAddress('amqp://localhost');
 message.setContentType('application/json');
 message.body = {array: [1, 2, 3, 4], object: {name: "John Smith", age: 65}};
 
 On the wire the above will be encoded as an opaque binary in an AMQP data section
-but will be deserialised into a JavaScript Object in exactly the same was as the
+but will be deserialized into a JavaScript Object in exactly the same was as the
 previous examples that use the AMQP type system.
 
 SUPPORT

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/data-uuid.js
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/data-uuid.js b/proton-c/bindings/javascript/data-uuid.js
index 4fee84a..18bc96a 100644
--- a/proton-c/bindings/javascript/data-uuid.js
+++ b/proton-c/bindings/javascript/data-uuid.js
@@ -27,7 +27,7 @@
 /**
  * Create a proton.Data.Uuid which is a type 4 UUID.
  * @classdesc
- * This class represents a type 4 UUID, wich may use crypto libraries to generate
+ * This class represents a type 4 UUID, which may use crypto libraries to generate
  * the UUID if supported by the platform (e.g. node.js or a modern browser)
  * @constructor proton.Data.Uuid
  * @param {number|Array|string} u a UUID. If null a type 4 UUID is generated wich may use crypto if
@@ -37,7 +37,7 @@
  * @property {Array} uuid is the compact array form of the UUID.
  */
 Data['Uuid'] = function(u) { // Data.Uuid Constructor.
-    // Helper to copy from emscriptem allocated storage into JavaScript Array.
+    // Helper to copy from emscripten allocated storage into JavaScript Array.
     function _p2a(p) {
         var uuid = new Array(16);
         for (var i = 0; i < 16; i++) {
@@ -46,7 +46,7 @@ Data['Uuid'] = function(u) { // Data.Uuid Constructor.
         return uuid;
     };
 
-    if (!u) { // Generate UUID using emscriptem's uuid_generate implementation.
+    if (!u) { // Generate UUID using emscripten's uuid_generate implementation.
         var sp = Runtime.stackSave();
         var p = allocate(16, 'i8', ALLOC_STACK); // Create temporary pointer storage.
         _uuid_generate(p);      // Generate UUID into allocated pointer.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/data.js
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/data.js b/proton-c/bindings/javascript/data.js
index 061d2bd..05e537b 100644
--- a/proton-c/bindings/javascript/data.js
+++ b/proton-c/bindings/javascript/data.js
@@ -204,7 +204,7 @@ Data.isBoolean = function(o) {
 
 // We use the dot notation rather than associative array form for protected
 // methods so they are visible to this "package", but the Closure compiler will
-// minify and obfuscate names, effectively making a defacto "protected" method.
+// minify and obfuscate names, effectively making a de facto "protected" method.
 
 /**
  * This helper method checks the supplied error code, converts it into an
@@ -317,7 +317,7 @@ _Data_['exit'] = function() {
 
 /**
  * Look up a value by name. N.B. Need to use getObject() to retrieve the actual
- * value after lookup suceeds.
+ * value after lookup succeeds.
  * @method lookup
  * @memberof! proton.Data#
  * @param {string} name the name of the property to look up.
@@ -1298,7 +1298,7 @@ _Data_['putMAP'] = function(object) {
  * Deserialise from an AMQP Map into a Native JavaScript Object.
  * @method getMAP
  * @memberof! proton.Data#
- * @returns {object} the deserialised Native JavaScript Object.
+ * @returns {object} the deserialized Native JavaScript Object.
  */
 _Data_['getMAP'] = function() {
     if (this['enter']()) {
@@ -1335,7 +1335,7 @@ _Data_['putLIST'] = function(array) {
  * Deserialise from an AMQP List into a Native JavaScript Array.
  * @method getLIST
  * @memberof! proton.Data#
- * @returns {Array} the deserialised Native JavaScript Array.
+ * @returns {Array} the deserialized Native JavaScript Array.
  */
 _Data_['getLIST'] = function() {
     if (this['enter']()) {
@@ -1366,7 +1366,7 @@ _Data_['putDESCRIBED'] = function(d) {
  * Deserialise from an AMQP Described into a proton.Data.Described.
  * @method getDESCRIBED
  * @memberof! proton.Data#
- * @returns {proton.Data.Described} the deserialised proton.Data.Described.
+ * @returns {proton.Data.Described} the deserialized proton.Data.Described.
  */
 _Data_['getDESCRIBED'] = function() {
     if (this['enter']()) {
@@ -1434,7 +1434,7 @@ _Data_['putARRAY'] = function(a) {
  * Deserialise from an AMQP Array into a proton.Data.Array.
  * @method getARRAY
  * @memberof! proton.Data#
- * @returns {proton.Data.Array} the deserialised proton.Data.Array.
+ * @returns {proton.Data.Array} the deserialized proton.Data.Array.
  */
 _Data_['getARRAY'] = function() {
     var metadata = this['getARRAYNODE']();
@@ -1571,7 +1571,7 @@ _Data_['putObject'] = function(obj) {
 /**
  * @method getObject
  * @memberof! proton.Data#
- * @returns {object} the JavaScript Object or primitive being deserialised.
+ * @returns {object} the JavaScript Object or primitive being deserialized.
  */
 _Data_['getObject'] = function() {
     var type = Data['TypeNames'][this.type()];

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/message.js
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/message.js b/proton-c/bindings/javascript/message.js
index 40b15f2..3ca9598 100644
--- a/proton-c/bindings/javascript/message.js
+++ b/proton-c/bindings/javascript/message.js
@@ -42,7 +42,7 @@ Module['Message'] = function() { // Message Constructor.
 
     // ************************* Public properties ****************************
 
-    // Intitialise with an empty Object so we can set properties in a natural way.
+    // Initialize with an empty Object so we can set properties in a natural way.
     // message.properties.prop1 = "foo";
     // message.properties.prop2 = "bar";
     this['properties'] = {};
@@ -70,7 +70,7 @@ Message['DEFAULT_PRIORITY'] = 4; /** Default priority for messages.*/
 
 // We use the dot notation rather than associative array form for protected
 // methods so they are visible to this "package", but the Closure compiler will
-// minify and obfuscate names, effectively making a defacto "protected" method.
+// minify and obfuscate names, effectively making a de facto "protected" method.
 
 /**
  * This helper method checks the supplied error code, converts it into an
@@ -196,7 +196,7 @@ _Message_._postDecode = function(decodeBinaryAsString) {
  * Free the Message.
  * <p>
  * N.B. This method has to be called explicitly in JavaScript as we can't
- * intercept finalisers, so we need to remember to free before removing refs.
+ * intercept finalizers, so we need to remember to free before removing refs.
  * @method free
  * @memberof! proton.Message#
  */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/messenger.js
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/messenger.js b/proton-c/bindings/javascript/messenger.js
index 5c96cb5..5f1df2e 100644
--- a/proton-c/bindings/javascript/messenger.js
+++ b/proton-c/bindings/javascript/messenger.js
@@ -63,7 +63,7 @@
  * Sending & Receiving Messages
  * ============================
  * </pre>
- * The {@link proton.Messenger} class works in conjuction with the {@link proton.Message} class.
+ * The {@link proton.Messenger} class works in conjunction with the {@link proton.Message} class.
  * The {@link proton.Message} class is a mutable holder of message content.
  * <p>
  * The put method copies its Message to the outgoing queue, and may
@@ -141,7 +141,7 @@ var _Messenger_ = Module['Messenger'].prototype;
 
 // We use the dot notation rather than associative array form for protected
 // methods so they are visible to this "package", but the Closure compiler will
-// minify and obfuscate names, effectively making a defacto "protected" method.
+// minify and obfuscate names, effectively making a de facto "protected" method.
 
 /**
  * This helper method checks the supplied error code, converts it into an
@@ -319,7 +319,7 @@ _Messenger_['isBlocking'] = function() {
  * by the Messenger. Call the stop method before destroying the Messenger.
  * <p>
  * N.B. This method has to be called explicitly in JavaScript as we can't
- * intercept finalisers, so we need to remember to free before removing refs.
+ * intercept finalizers, so we need to remember to free before removing refs.
  * @method free
  * @memberof! proton.Messenger#
  */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/javascript/module.js
----------------------------------------------------------------------
diff --git a/proton-c/bindings/javascript/module.js b/proton-c/bindings/javascript/module.js
index 3603de3..1eac6cc 100644
--- a/proton-c/bindings/javascript/module.js
+++ b/proton-c/bindings/javascript/module.js
@@ -327,7 +327,7 @@ Module.EventDispatch = new function() { // Note the use of new to create a Singl
              * actually free and remove the selectable is deferred until next
              * time round the (internal JavaScript) event loop. This turned out
              * to be necessary because in some cases the ws WebSocket library
-             * calls the onclose callback (concurrently!!) before the onmessage
+             * calls the on_close callback (concurrently!!) before the on_message
              * callback exits, which could result in _pn_selectable_free being
              * called whilst _pn_selectable_writable is executing, which is bad!!
              */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/perl/lib/qpid/proton/Data.pm
----------------------------------------------------------------------
diff --git a/proton-c/bindings/perl/lib/qpid/proton/Data.pm b/proton-c/bindings/perl/lib/qpid/proton/Data.pm
index 494a8f3..dccf2fc 100644
--- a/proton-c/bindings/perl/lib/qpid/proton/Data.pm
+++ b/proton-c/bindings/perl/lib/qpid/proton/Data.pm
@@ -30,7 +30,7 @@ qpid::proton::Data
 The B<Data> class provides an interface for decoding, extract, creating and
 encoding arbitrary AMQP data. A B<Data> object contains a tree of AMQP values.
 Leaf nodes in this tree correspond to scalars in the AMQP type system such as
-B<INT> or B<STRING>. Integerior nodes in this tree correspond to compound values
+B<INT> or B<STRING>. Interior nodes in this tree correspond to compound values
 in the AMQP type system such as B<LIST>, B<MAP>, B<ARRAY> or B<DESCRIBED>. The
 root node of the tree is the B<Data> object itself and can have an arbitrary
 number of children.
@@ -41,8 +41,8 @@ and/or added by using the B<next>, B<prev>, B<enter> and B<exit> methods to
 navigate to the desired location in the tree and using the supplied variety of
 mutator and accessor methods to access or add a value of the desired type.
 
-The mutator methods will always add a vlaue I<after> the current node in the
-tree. If the current node has a next sibling the mutaor method will overwrite
+The mutator methods will always add a value I<after> the current node in the
+tree. If the current node has a next sibling the mutator method will overwrite
 the value on this node. If there is no current node or the current node has no
 next sibling then one will be added. The accessor methods always set the
 add/modified node to the current node. The accessor methods read the value of

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/perl/tests/hash_helper.t
----------------------------------------------------------------------
diff --git a/proton-c/bindings/perl/tests/hash_helper.t b/proton-c/bindings/perl/tests/hash_helper.t
index 8f1ea3d..45277a6 100644
--- a/proton-c/bindings/perl/tests/hash_helper.t
+++ b/proton-c/bindings/perl/tests/hash_helper.t
@@ -34,7 +34,7 @@ my $result;
 # raises an error when getting a hash from a null data object
 #=============================================================================
 dies_ok(sub {qpid::proton::get_map_from(undef);},
-        "Raises an error when getting a hash froma  null data object");
+        "Raises an error when getting a hash from a null data object");
 
 
 #=============================================================================

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/perl/tests/message.t
----------------------------------------------------------------------
diff --git a/proton-c/bindings/perl/tests/message.t b/proton-c/bindings/perl/tests/message.t
index ee55361..d907207 100644
--- a/proton-c/bindings/perl/tests/message.t
+++ b/proton-c/bindings/perl/tests/message.t
@@ -58,7 +58,7 @@ dies_ok(sub {$message->set_ttl(0 - $ttl)}, 'TTL cannot be negative');
 $message->set_ttl(0);
 ok($message->get_ttl() == 0, 'TTL can be zero');
 $message->set_ttl($ttl);
-ok($message->get_ttl() == $ttl, 'TTL can be postive');
+ok($message->get_ttl() == $ttl, 'TTL can be positive');
 
 # first acquirer
 $message->set_first_acquirer(1);
@@ -76,7 +76,7 @@ dies_ok(sub {$message->set_delivery_count(0 - $delivery_count)},
 $message->set_delivery_count(0);
 ok($message->get_delivery_count() == 0, 'Delivery count can be zero');
 $message->set_delivery_count($delivery_count);
-ok ($message->get_delivery_count() == $delivery_count, 'Delivery count can be postiive');
+ok ($message->get_delivery_count() == $delivery_count, 'Delivery count can be positive');
 
 # message id
 my $message_id = random_string(16);

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/docs/overview.rst
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/docs/overview.rst b/proton-c/bindings/python/docs/overview.rst
index f82deb2..b11e163 100644
--- a/proton-c/bindings/python/docs/overview.rst
+++ b/proton-c/bindings/python/docs/overview.rst
@@ -44,11 +44,11 @@ The :py:class:`~proton.reactor.Container` class is a convenient entry
 point into the API, allowing connections and links to be
 established. Applications are structured as one or more event
 handlers. Handlers can be set at Container, Connection, or Link
-scope. Messages are sent by establishing an approprate sender and
+scope. Messages are sent by establishing an appropriate sender and
 invoking its :py:meth:`~proton.Sender.send()` method. This is
 typically done when the sender is sendable, a condition indicated by
 the :py:meth:`~proton.handlers.MessagingHandler.on_sendable()` event, to
-avoid execessive build up of messages. Messages can be received by
+avoid excessive build up of messages. Messages can be received by
 establishing an appropriate receiver and handling the
 :py:meth:`~proton.handlers.MessagingHandler.on_message()` event.
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/docs/tutorial.rst
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/docs/tutorial.rst b/proton-c/bindings/python/docs/tutorial.rst
index ee8a12f..95cde3a 100644
--- a/proton-c/bindings/python/docs/tutorial.rst
+++ b/proton-c/bindings/python/docs/tutorial.rst
@@ -237,7 +237,7 @@ The code here is not too different from the simple receiver
 example. When we receive a request however, we look at the
 :py:attr:`~proton.Message.reply_to` address on the
 :py:class:`~proton.Message` and create a sender for that over which to
-send the response. We'll cache the senders incase we get further
+send the response. We'll cache the senders in case we get further
 requests with the same reply_to.
 
 Now let's create a simple client to test this service out.
@@ -291,7 +291,7 @@ When creating the receiver, we specify a Selector object as an
 option. The options argument can take a single object or a
 list. Another option that is sometimes of interest when using a broker
 is the ability to 'browse' the messages on a queue, rather than
-consumig them. This is done in AMQP by specifying a distribution mode
+consuming them. This is done in AMQP by specifying a distribution mode
 of 'copy' (instead of 'move' which is the expected default for
 queues). An example of that is shown next:
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/proton/__init__.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/__init__.py b/proton-c/bindings/python/proton/__init__.py
index 0dda550..5c4dea7 100644
--- a/proton-c/bindings/python/proton/__init__.py
+++ b/proton-c/bindings/python/proton/__init__.py
@@ -162,7 +162,7 @@ class Timeout(ProtonException):
 
 class Interrupt(ProtonException):
   """
-  An interrupt exception indicaes that a blocking operation was interrupted.
+  An interrupt exception indicates that a blocking operation was interrupted.
   """
   pass
 
@@ -176,7 +176,7 @@ class MessengerException(ProtonException):
 class MessageException(ProtonException):
   """
   The MessageException class is the root of the message exception
-  hierarhcy. All exceptions generated by the Message class derive from
+  hierarchy. All exceptions generated by the Message class derive from
   this exception.
   """
   pass
@@ -247,7 +247,7 @@ class Messenger(object):
   Sending & Receiving Messages
   ============================
 
-  The L{Messenger} class works in conjuction with the L{Message} class. The
+  The L{Messenger} class works in conjunction with the L{Message} class. The
   L{Message} class is a mutable holder of message content.
 
   The L{put} method copies its L{Message} to the outgoing queue, and may
@@ -2836,7 +2836,7 @@ class Link(Wrapper, Endpoint):
 
   @property
   def credit(self):
-    """The amount of oustanding credit on this link."""
+    """The amount of outstanding credit on this link."""
     return pn_link_credit(self._impl)
 
   @property
@@ -3268,7 +3268,7 @@ class Delivery(Wrapper):
 
   def settle(self):
     """
-    Settles the delivery locally. This indicates the aplication
+    Settles the delivery locally. This indicates the application
     considers the delivery complete and does not wish to receive any
     further events about it. Every delivery should be settled locally.
     """
@@ -4167,7 +4167,7 @@ class Url(object):
 
   <scheme>://<user>:<password>@<host>:<port>/<path>
 
-  All components can be None if not specifeid in the URL string.
+  All components can be None if not specified in the URL string.
 
   The port can be specified as a service name, e.g. 'amqp' in the
   URL string but Url.port always gives the integer value.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/proton/handlers.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/handlers.py b/proton-c/bindings/python/proton/handlers.py
index 55e02b1..8ecf6da 100644
--- a/proton-c/bindings/python/proton/handlers.py
+++ b/proton-c/bindings/python/proton/handlers.py
@@ -88,7 +88,7 @@ class OutgoingMessageHandler(Handler):
     def on_settled(self, event):
         """
         Called when the remote peer has settled the outgoing
-        message. This is the point at which it shouod never be
+        message. This is the point at which it should never be
         retransmitted.
         """
         if self.delegate != None:
@@ -184,7 +184,7 @@ class IncomingMessageHandler(Handler, Acking):
         """
         Called when a message is received. The message itself can be
         obtained as a property on the event. For the purpose of
-        refering to this message in further actions (e.g. if
+        referring to this message in further actions (e.g. if
         explicitly accepting it, the ``delivery`` should be used, also
         obtainable via a property on the event.
         """
@@ -518,7 +518,7 @@ class MessagingHandler(Handler, Acking):
     def on_settled(self, event):
         """
         Called when the remote peer has settled the outgoing
-        message. This is the point at which it shouod never be
+        message. This is the point at which it should never be
         retransmitted.
         """
         pass
@@ -526,7 +526,7 @@ class MessagingHandler(Handler, Acking):
         """
         Called when a message is received. The message itself can be
         obtained as a property on the event. For the purpose of
-        refering to this message in further actions (e.g. if
+        referring to this message in further actions (e.g. if
         explicitly accepting it, the ``delivery`` should be used, also
         obtainable via a property on the event.
         """

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/proton/reactor.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/reactor.py b/proton-c/bindings/python/proton/reactor.py
index b8bd96f..0fa1c4b 100644
--- a/proton-c/bindings/python/proton/reactor.py
+++ b/proton-c/bindings/python/proton/reactor.py
@@ -203,7 +203,7 @@ class Reactor(Wrapper):
 
     def connection_to_host(self, host, port, handler=None):
         """Create an outgoing Connection that will be managed by the reactor.
-        The reator's pn_iohandler will create a socket connection to the host
+        The reactor's pn_iohandler will create a socket connection to the host
         once the connection is opened.
         """
         conn = self.connection(handler)
@@ -274,7 +274,7 @@ class EventInjector(object):
     def close(self):
         """
         Request that this EventInjector be closed. Existing events
-        will be dispctahed on the reactors event dispactch thread,
+        will be dispatched on the reactors event dispatch thread,
         then this will be removed from the set of interest.
         """
         self._closed = True
@@ -665,7 +665,7 @@ class SSLConfig(object):
 
 class Container(Reactor):
     """A representation of the AMQP concept of a 'container', which
-       lossely speaking is something that establishes links to or from
+       loosely speaking is something that establishes links to or from
        another container, over which messages are transfered. This is
        an extension to the Reactor class that adds convenience methods
        for creating connections and sender- or receiver- links.
@@ -709,7 +709,7 @@ class Container(Reactor):
         socket is alive.
 
         @param ssl_domain: SSL configuration in the form of an
-        instance of proton.SSLdomain.
+        instance of proton.SSLDomain.
 
         @param handler: a connection scoped handler that will be
         called to process any events in the scope of this connection
@@ -795,7 +795,7 @@ class Container(Reactor):
         specified as the second argument (or as a keyword
         argument). The source address can also be specified if
         desired. (2) Alternatively a URL can be passed as the first
-        argument. In this case a new connection will be establised on
+        argument. In this case a new connection will be established on
         which the link will be attached. If a path is specified and
         the target is not, then the path of the URL is used as the
         target address.
@@ -836,7 +836,7 @@ class Container(Reactor):
         specified as the second argument (or as a keyword
         argument). The target address can also be specified if
         desired. (2) Alternatively a URL can be passed as the first
-        argument. In this case a new connection will be establised on
+        argument. In this case a new connection will be established on
         which the link will be attached. If a path is specified and
         the source is not, then the path of the URL is used as the
         target address.

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/proton/utils.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/utils.py b/proton-c/bindings/python/proton/utils.py
index c9a3654..cf36bbe 100644
--- a/proton-c/bindings/python/proton/utils.py
+++ b/proton-c/bindings/python/proton/utils.py
@@ -336,7 +336,7 @@ class AtomicCount(object):
 
 class SyncRequestResponse(IncomingMessageHandler):
     """
-    Implementation of the synchronous request-responce (aka RPC) pattern.
+    Implementation of the synchronous request-response (aka RPC) pattern.
     @ivar address: Address for all requests, may be None.
     @ivar connection: Connection for requests and responses.
     """
@@ -351,7 +351,7 @@ class SyncRequestResponse(IncomingMessageHandler):
         @param connection: A L{BlockingConnection}
         @param address: Address for all requests.
             If not specified, each request must have the address property set.
-            Sucessive messages may have different addresses.
+            Successive messages may have different addresses.
         """
         super(SyncRequestResponse, self).__init__()
         self.connection = connection

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/bindings/python/setup.py.in
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/setup.py.in b/proton-c/bindings/python/setup.py.in
index dd6a3a8..7513315 100755
--- a/proton-c/bindings/python/setup.py.in
+++ b/proton-c/bindings/python/setup.py.in
@@ -38,7 +38,7 @@ qpid-proton requires installed to make this setup work.
 
 From the Python side, this scripts overrides 1 command - build_ext - and it adds a
 new one. The latter - Configure - is called from the former to setup/discover what's
-in the system. The rest of the comands and steps are done normally without any kind
+in the system. The rest of the commands and steps are done normally without any kind
 of monkey patching.
 """
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/codec.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/codec.h b/proton-c/include/proton/codec.h
index bcbbbf0..1755f53 100644
--- a/proton-c/include/proton/codec.h
+++ b/proton-c/include/proton/codec.h
@@ -191,7 +191,7 @@ typedef enum {
 PN_EXTERN const char *pn_type_name(pn_type_t type);
 
 /**
- * A descriminated union that holds any scalar AMQP value. The type
+ * A discriminated union that holds any scalar AMQP value. The type
  * field indicates the AMQP type of the value, and the union may be
  * used to access the value for a given type.
  *
@@ -389,7 +389,7 @@ PN_EXTERN void pn_data_free(pn_data_t *data);
 PN_EXTERN int pn_data_errno(pn_data_t *data);
 
 /**
- * Access the current error for a givn pn_data_t.
+ * Access the current error for a given pn_data_t.
  *
  * 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
@@ -425,7 +425,7 @@ PN_EXTERN void pn_data_clear(pn_data_t *data);
 /**
  * Returns the total number of nodes contained in a pn_data_t object.
  * This includes all parents, children, siblings, grandchildren, etc.
- * In other words the count of all ancesters and descendents of the
+ * In other words the count of all ancestors and descendants of the
  * current node, along with the current node if there is one.
  *
  * @param data a pn_data_t object
@@ -518,7 +518,7 @@ PN_EXTERN int pn_data_print(pn_data_t *data);
  * @param data a pn_data_t object
  * @param bytes a buffer to write the output to
  * @param size a pointer to the size of the buffer
- * @return zero on succes, or an error on failure
+ * @return zero on success, or an error on failure
  */
 PN_EXTERN int pn_data_format(pn_data_t *data, char *bytes, size_t *size);
 
@@ -1208,7 +1208,7 @@ PN_EXTERN pn_atom_t pn_data_get_atom(pn_data_t *data);
  * data object will be lost.
  *
  * @param data a pn_data_t object
- * @param src the sourc pn_data_t to copy from
+ * @param src the source pn_data_t to copy from
  * @return zero on success or an error code on failure
  */
 PN_EXTERN int pn_data_copy(pn_data_t *data, pn_data_t *src);
@@ -1217,7 +1217,7 @@ PN_EXTERN int pn_data_copy(pn_data_t *data, pn_data_t *src);
  * Append the contents of another pn_data_t object.
  *
  * @param data a pn_data_t object
- * @param src the sourc pn_data_t to append from
+ * @param src the source pn_data_t to append from
  * @return zero on success or an error code on failure
  */
 PN_EXTERN int pn_data_append(pn_data_t *data, pn_data_t *src);
@@ -1227,7 +1227,7 @@ PN_EXTERN int pn_data_append(pn_data_t *data, pn_data_t *src);
  * object.
  *
  * @param data a pn_data_t object
- * @param src the sourc pn_data_t to append from
+ * @param src the source pn_data_t to append from
  * @param limit the maximum number of values to append
  * @return zero on success or an error code on failure
  */

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/connection.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/connection.h b/proton-c/include/proton/connection.h
index 4984040..ff6c68c 100644
--- a/proton-c/include/proton/connection.h
+++ b/proton-c/include/proton/connection.h
@@ -294,10 +294,10 @@ PN_EXTERN void pn_connection_set_container(pn_connection_t *connection, const ch
  * Set the authentication username for a client connection
  *
  * 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.
+ * to a transport and it isn't allowed to change them after the binding.
  *
  * If not set then no authentication will be negotiated unless the client
- * sasl layer is explicitly created (this would be for sometting like Kerberos
+ * 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)
  *
@@ -310,7 +310,7 @@ PN_EXTERN void pn_connection_set_user(pn_connection_t *connection, const char *u
  * Set the authentication password for a client connection
  *
  * 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.
+ * to a transport and it isn't allowed to change them after the binding.
  *
  * 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
@@ -393,7 +393,7 @@ PN_EXTERN const char *pn_connection_remote_hostname(pn_connection_t *connection)
  *
  * This operation will return a pointer to a ::pn_data_t object that
  * is valid until the connection object is freed. Any data contained
- * by the ::pn_data_t object will be sent as the offered capabilites
+ * by the ::pn_data_t 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.
  *
@@ -411,7 +411,7 @@ PN_EXTERN pn_data_t *pn_connection_offered_capabilities(pn_connection_t *connect
  *
  * This operation will return a pointer to a ::pn_data_t object that
  * is valid until the connection object is freed. Any data contained
- * by the ::pn_data_t object will be sent as the desired capabilites
+ * by the ::pn_data_t 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.
  *
@@ -441,7 +441,7 @@ PN_EXTERN pn_data_t *pn_connection_desired_capabilities(pn_connection_t *connect
 PN_EXTERN pn_data_t *pn_connection_properties(pn_connection_t *connection);
 
 /**
- * Access the AMQP offered capabilites supplied by the remote
+ * Access the AMQP offered capabilities supplied by the remote
  * connection endpoint.
  *
  * This operation will return a pointer to a ::pn_data_t object that
@@ -455,7 +455,7 @@ PN_EXTERN pn_data_t *pn_connection_properties(pn_connection_t *connection);
 PN_EXTERN pn_data_t *pn_connection_remote_offered_capabilities(pn_connection_t *connection);
 
 /**
- * Access the AMQP desired capabilites supplied by the remote
+ * Access the AMQP desired capabilities supplied by the remote
  * connection endpoint.
  *
  * This operation will return a pointer to a ::pn_data_t object that

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/connection_driver.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/connection_driver.h b/proton-c/include/proton/connection_driver.h
index d0ad150..8e39551 100644
--- a/proton-c/include/proton/connection_driver.h
+++ b/proton-c/include/proton/connection_driver.h
@@ -241,13 +241,13 @@ PN_EXTERN pn_connection_driver_t* pn_event_batch_connection_driver(pn_event_batc
 
 /**
  * The write side of the transport is closed, it will no longer produce bytes to write to
- * external IO. Synonynm for PN_TRANSPORT_HEAD_CLOSED
+ * external IO. Synonym for PN_TRANSPORT_HEAD_CLOSED
  */
 #define PN_TRANSPORT_WRITE_CLOSED PN_TRANSPORT_HEAD_CLOSED
 
 /**
  * The read side of the transport is closed, it will no longer read bytes from external
- * IO. Alisas for PN_TRANSPORT_TAIL_CLOSED
+ * IO. Alias for PN_TRANSPORT_TAIL_CLOSED
  */
 #define PN_TRANSPORT_READ_CLOSED PN_TRANSPORT_TAIL_CLOSED
 

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/delivery.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/delivery.h b/proton-c/include/proton/delivery.h
index 8e7f421..a4dc1b6 100644
--- a/proton-c/include/proton/delivery.h
+++ b/proton-c/include/proton/delivery.h
@@ -324,8 +324,8 @@ PN_EXTERN bool pn_delivery_buffered(pn_delivery_t *delivery);
  * 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
+ * has changed. A delivery will never be both readable and writable,
+ * but it may be both readable and updated or both writable and
  * updated.
  *
  * @param[in] connection the connection

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/event.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/event.h b/proton-c/include/proton/event.h
index fc2e5ea..206828b 100644
--- a/proton-c/include/proton/event.h
+++ b/proton-c/include/proton/event.h
@@ -344,7 +344,7 @@ typedef enum {
   PN_PROACTOR_INACTIVE,
 
   /**
-   * The listener is listeneing.
+   * The listener is listening.
    * Events of this type point to the @ref pn_listener_t.
    */
   PN_LISTENER_OPEN
@@ -562,7 +562,7 @@ PN_EXTERN pn_event_t *pn_event_batch_next(pn_event_batch_t *batch);
 /**
  * @cond INTERNAL
  *
- * pn_event_batch_next() can be re-implemented for different behaviors in different contextxs.
+ * pn_event_batch_next() can be re-implemented for different behaviors in different contexts.
  */
 struct pn_event_batch_t {
   pn_event_t *(*next_event)(pn_event_batch_t *batch);

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/e22ca536/proton-c/include/proton/link.h
----------------------------------------------------------------------
diff --git a/proton-c/include/proton/link.h b/proton-c/include/proton/link.h
index 40f8f62..8099a32 100644
--- a/proton-c/include/proton/link.h
+++ b/proton-c/include/proton/link.h
@@ -476,7 +476,7 @@ typedef enum {
                            initially unsettled. */
   PN_SND_SETTLED = 1, /**< The sender will send all deliveries settled
                          to the receiver. */
-  PN_SND_MIXED = 2 /**< The sender may send a mixure of settled and
+  PN_SND_MIXED = 2 /**< The sender may send a mixture of settled and
                       unsettled deliveries. */
 } pn_snd_settle_mode_t;
 


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


[3/4] qpid-proton git commit: PROTON-1522: Define Url repr to exclude user and password; use repr in logging

Posted by jr...@apache.org.
PROTON-1522: Define Url repr to exclude user and password; use repr in logging


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

Branch: refs/heads/master
Commit: 5c746ceb00b567c6345c3b4da26dc334480b3f6f
Parents: 85755ac
Author: Justin Ross <jr...@apache.org>
Authored: Fri Dec 8 12:26:53 2017 -0800
Committer: Justin Ross <jr...@apache.org>
Committed: Fri Dec 8 12:59:19 2017 -0800

----------------------------------------------------------------------
 proton-c/bindings/python/proton/__init__.py | 3 ++-
 proton-c/bindings/python/proton/reactor.py  | 2 +-
 2 files changed, 3 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/5c746ceb/proton-c/bindings/python/proton/__init__.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/__init__.py b/proton-c/bindings/python/proton/__init__.py
index 21076ee..0dda550 100644
--- a/proton-c/bindings/python/proton/__init__.py
+++ b/proton-c/bindings/python/proton/__init__.py
@@ -4258,7 +4258,8 @@ class Url(object):
 
   def __str__(self): return pn_url_str(self._url)
 
-  def __repr__(self): return "Url(%r)" % str(self)
+  def __repr__(self):
+    return "Url(%s://%s/%s)" % (self.scheme, self.host, self.path)
 
   def __eq__(self, x): return str(self) == str(x)
   def __ne__(self, x): return not self == x

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/5c746ceb/proton-c/bindings/python/proton/reactor.py
----------------------------------------------------------------------
diff --git a/proton-c/bindings/python/proton/reactor.py b/proton-c/bindings/python/proton/reactor.py
index e9ede47..b8bd96f 100644
--- a/proton-c/bindings/python/proton/reactor.py
+++ b/proton-c/bindings/python/proton/reactor.py
@@ -554,7 +554,7 @@ class Connector(Handler):
         # if virtual-host not set, use host from address as default
         if self.virtual_host is None:
             connection.hostname = url.host
-        log.debug("connecting to %s..." % url)
+        log.debug("connecting to %r..." % url)
 
         transport = Transport()
         if self.sasl_enabled:


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