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

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

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