You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by rr...@apache.org on 2019/05/10 00:29:28 UTC

[trafficserver] branch master updated: Fixes typos in various documentation files

This is an automated email from the ASF dual-hosted git repository.

rrm pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/trafficserver.git


The following commit(s) were added to refs/heads/master by this push:
     new c958234  Fixes typos in various documentation files
c958234 is described below

commit c958234c48cd28d5da13e73cf8fc652683c6e375
Author: Yongjian Xu <yo...@gmail.com>
AuthorDate: Thu Jun 1 16:40:34 2017 +0800

    Fixes typos in various documentation files
---
 doc/admin-guide/plugins/geoip_acl.en.rst             |  2 +-
 .../admin-guide/files/parent.config.en.po            |  6 +++---
 .../admin-guide/files/records.config.en.po           |  2 +-
 .../LC_MESSAGES/admin-guide/plugins/geoip_acl.en.po  |  2 +-
 .../api/functions/TSVConnReenable.en.po              |  2 +-
 plugins/experimental/metalink/test/location          |  2 +-
 plugins/experimental/slice/ContentRange.h            |  2 +-
 plugins/experimental/slice/server.cc                 |  4 ++--
 proxy/CacheControl.cc                                |  2 +-
 proxy/CacheControl.h                                 |  2 +-
 proxy/ControlMatcher.cc                              |  4 ++--
 proxy/IPAllow.h                                      |  2 +-
 proxy/ParentSelection.cc                             |  2 +-
 proxy/ParentSelection.h                              |  2 +-
 proxy/PluginVC.h                                     |  2 +-
 proxy/hdrs/HdrHeap.cc                                |  4 ++--
 proxy/hdrs/HdrHeap.h                                 |  4 ++--
 proxy/hdrs/HdrToken.h                                |  4 ++--
 proxy/hdrs/HttpCompat.cc                             |  2 +-
 proxy/hdrs/MIME.cc                                   |  2 +-
 proxy/http/ForwardedConfig.cc                        |  2 +-
 proxy/http/Http1ClientSession.cc                     |  2 +-
 proxy/http/Http1ClientTransaction.cc                 |  2 +-
 proxy/http/HttpBodyFactory.h                         |  2 +-
 proxy/http/HttpCacheSM.cc                            |  2 +-
 proxy/http/HttpConfig.h                              |  2 +-
 proxy/http/HttpConnectionCount.h                     |  4 ++--
 proxy/http/HttpPages.cc                              |  2 +-
 proxy/http/HttpPages.h                               |  2 +-
 proxy/http/HttpSM.cc                                 |  6 +++---
 proxy/http/HttpSM.h                                  |  4 ++--
 proxy/http/HttpServerSession.h                       |  4 ++--
 proxy/http/HttpTransact.cc                           | 20 ++++++++++----------
 proxy/http/HttpTransactCache.cc                      |  6 +++---
 proxy/http/HttpTransactHeaders.cc                    |  2 +-
 proxy/http/HttpTunnel.cc                             |  4 ++--
 proxy/http2/Http2ConnectionState.cc                  |  4 ++--
 proxy/http2/Http2ConnectionState.h                   |  2 +-
 proxy/http2/Http2Stream.h                            |  4 ++--
 proxy/logging/LogAccess.cc                           |  4 ++--
 proxy/logging/LogFile.cc                             |  2 +-
 proxy/logging/LogFilter.h                            |  2 +-
 proxy/logging/LogFormat.cc                           |  4 ++--
 proxy/logging/LogObject.cc                           |  2 +-
 proxy/logging/LogStandalone.cc                       |  2 +-
 proxy/logging/LogUtils.cc                            |  2 +-
 src/traffic_logstats/logstats.cc                     |  2 +-
 tests/gold_tests/autest-site/trafficserver.test.ext  |  2 +-
 tests/gold_tests/headers/hsts.test.py                |  2 +-
 tests/gold_tests/headers/http408.test.py             |  2 +-
 50 files changed, 78 insertions(+), 78 deletions(-)

diff --git a/doc/admin-guide/plugins/geoip_acl.en.rst b/doc/admin-guide/plugins/geoip_acl.en.rst
index 15e5af7..13d3368 100644
--- a/doc/admin-guide/plugins/geoip_acl.en.rst
+++ b/doc/admin-guide/plugins/geoip_acl.en.rst
@@ -89,7 +89,7 @@ Finally, there's one additional parameter option that can be used ::
 
     @pparam=html::/some/path.html
 
-This will override the default reponse body for the denied responses
+This will override the default response body for the denied responses
 with a custom piece of HTML. This can be useful to explain to your users
 why they are getting denied access to a particular piece of content.
 This configuration can be used with any of the use cases described
diff --git a/doc/locale/ja/LC_MESSAGES/admin-guide/files/parent.config.en.po b/doc/locale/ja/LC_MESSAGES/admin-guide/files/parent.config.en.po
index 63eb484..191d999 100644
--- a/doc/locale/ja/LC_MESSAGES/admin-guide/files/parent.config.en.po
+++ b/doc/locale/ja/LC_MESSAGES/admin-guide/files/parent.config.en.po
@@ -283,7 +283,7 @@ msgstr ""
 #: ../../../admin-guide/files/parent.config.en.rst:162
 msgid ""
 "``unavailable_server_retry`` - If the parent returns a 503 response or if "
-"the reponse matches a list of http 5xx responses defined in "
+"the response matches a list of http 5xx responses defined in "
 "``unavailable_server_retry_responses``, the currently selected parent is "
 "marked down and a new parent is selected to retry the request.  The number "
 "of retries is controlled by ``max_unavailable_server_retries`` which is set "
@@ -317,7 +317,7 @@ msgstr ""
 msgid ""
 "By default the value for ``max_simple_retries`` is 1.  It may be set to any "
 "value in the range 1 to 5. If ``parent_is_proxy`` is false and "
-"``parent_retry`` is set to ``simple_retry`` or ``both`` a 404 reponse from "
+"``parent_retry`` is set to ``simple_retry`` or ``both`` a 404 response from "
 "a parent origin server will cause the request to be retried using a new "
 "parent at most 1 to 5 times as configured by ``max_simple_retries``."
 msgstr ""
@@ -331,7 +331,7 @@ msgid ""
 "By default the value for ``max_unavailable_server_retries`` is 1.  It may "
 "be set to any value in the range 1 to 5. If ``parent_is_proxy`` is false "
 "and ``parent_retry`` is set to ``unavailable_server_retries`` or ``both`` a "
-"503 reponse by default or any http 5xx response listed in the list "
+"503 response by default or any http 5xx response listed in the list "
 "``unavailable_server_retry_responses`` from a parent origin server will "
 "cause the request to be retried using a new parent after first marking the "
 "current parent down.  The request will be retried at most 1 to 5 times as "
diff --git a/doc/locale/ja/LC_MESSAGES/admin-guide/files/records.config.en.po b/doc/locale/ja/LC_MESSAGES/admin-guide/files/records.config.en.po
index baab72c..3637b18 100644
--- a/doc/locale/ja/LC_MESSAGES/admin-guide/files/records.config.en.po
+++ b/doc/locale/ja/LC_MESSAGES/admin-guide/files/records.config.en.po
@@ -3554,7 +3554,7 @@ msgid "The DNS servers."
 msgstr ""
 
 #: ../../../admin-guide/files/records.config.en.rst:2295
-msgid "Indicates whether to use SRV records for orgin server lookup."
+msgid "Indicates whether to use SRV records for origin server lookup."
 msgstr ""
 
 #: ../../../admin-guide/files/records.config.en.rst:2299
diff --git a/doc/locale/ja/LC_MESSAGES/admin-guide/plugins/geoip_acl.en.po b/doc/locale/ja/LC_MESSAGES/admin-guide/plugins/geoip_acl.en.po
index 884b3ed..21671ec 100644
--- a/doc/locale/ja/LC_MESSAGES/admin-guide/plugins/geoip_acl.en.po
+++ b/doc/locale/ja/LC_MESSAGES/admin-guide/plugins/geoip_acl.en.po
@@ -98,7 +98,7 @@ msgstr ""
 
 #: ../../admin-guide/plugins/geoip_acl.en.rst:92
 msgid ""
-"This will override the default reponse body for the denied responses with a "
+"This will override the default response body for the denied responses with a "
 "custom piece of HTML. This can be useful to explain to your users why they "
 "are getting denied access to a particular piece of content. This "
 "configuration can be used with any of the use cases described above."
diff --git a/doc/locale/ja/LC_MESSAGES/developer-guide/api/functions/TSVConnReenable.en.po b/doc/locale/ja/LC_MESSAGES/developer-guide/api/functions/TSVConnReenable.en.po
index 6e9c935..a33e106 100644
--- a/doc/locale/ja/LC_MESSAGES/developer-guide/api/functions/TSVConnReenable.en.po
+++ b/doc/locale/ja/LC_MESSAGES/developer-guide/api/functions/TSVConnReenable.en.po
@@ -58,7 +58,7 @@ msgstr ""
 #: ../../developer-guide/api/functions/TSVConnReenable.en.rst:34
 msgid ""
 "Reenable the SSL connection :arg:`svc`. If a plugin hook is called, ATS "
-"processing on that connnection will not resume until this is invoked for "
+"processing on that connection will not resume until this is invoked for "
 "that connection."
 msgstr ""
 
diff --git a/plugins/experimental/metalink/test/location b/plugins/experimental/metalink/test/location
index 0ab835b..30ed488 100755
--- a/plugins/experimental/metalink/test/location
+++ b/plugins/experimental/metalink/test/location
@@ -114,7 +114,7 @@ class factory(protocol.ClientFactory):
             def handleStatus(version, status, message):
                 del ctx.handleHeader
 
-                def handleStatus(version, staus, message):
+                def handleStatus(version, status, message):
                     def handleHeader(k, v):
                         if k.lower() == 'location':
                             if v != 'http://{0}:{1}/location'.format(*origin.socket.getsockname()):
diff --git a/plugins/experimental/slice/ContentRange.h b/plugins/experimental/slice/ContentRange.h
index 87de631..2412e66 100644
--- a/plugins/experimental/slice/ContentRange.h
+++ b/plugins/experimental/slice/ContentRange.h
@@ -21,7 +21,7 @@
 #include "ts/ts.h"
 
 /**
-  represents value parsed from a blocked Content-Range reponse header field.
+  represents value parsed from a blocked Content-Range response header field.
   Range is converted from closed range into a half open range for.
  */
 struct ContentRange {
diff --git a/plugins/experimental/slice/server.cc b/plugins/experimental/slice/server.cc
index 37016de..5d94417 100644
--- a/plugins/experimental/slice/server.cc
+++ b/plugins/experimental/slice/server.cc
@@ -70,7 +70,7 @@ handleFirstServerHeader(Data *const data, TSCont const contp)
 
   // only process a 206, everything else gets a pass through
   if (TS_HTTP_STATUS_PARTIAL_CONTENT != header.status()) {
-    DEBUG_LOG("Initial reponse other than 206: %d", header.status());
+    DEBUG_LOG("Initial response other than 206: %d", header.status());
     data->m_bail = true;
 
     TSHttpHdrPrint(header.m_buffer, header.m_lochdr, data->m_dnstream.m_write.m_iobuf);
@@ -357,7 +357,7 @@ void
 handle_server_resp(TSCont contp, TSEvent event, Data *const data)
 {
   if (TS_EVENT_VCONN_READ_READY == event || TS_EVENT_VCONN_READ_COMPLETE == event) {
-    // has block reponse header been parsed??
+    // has block response header been parsed??
     if (!data->m_server_block_header_parsed) {
       // the server response header didn't fit into the input buffer??
       if (TS_PARSE_DONE !=
diff --git a/proxy/CacheControl.cc b/proxy/CacheControl.cc
index 423584e..d41b56d 100644
--- a/proxy/CacheControl.cc
+++ b/proxy/CacheControl.cc
@@ -23,7 +23,7 @@
 
 /*****************************************************************************
  *
- *  CacheControl.cc - Implementation to Cache Control systtem
+ *  CacheControl.cc - Implementation to Cache Control system
  *
  *
  ****************************************************************************/
diff --git a/proxy/CacheControl.h b/proxy/CacheControl.h
index 3c088b6..83ebc46 100644
--- a/proxy/CacheControl.h
+++ b/proxy/CacheControl.h
@@ -23,7 +23,7 @@
 
 /*****************************************************************************
  *
- *  CacheControl.h - Interface to Cache Control systtem
+ *  CacheControl.h - Interface to Cache Control system
  *
  *
  ****************************************************************************/
diff --git a/proxy/ControlMatcher.cc b/proxy/ControlMatcher.cc
index 8034ecf..57c1869 100644
--- a/proxy/ControlMatcher.cc
+++ b/proxy/ControlMatcher.cc
@@ -156,7 +156,7 @@ HostMatcher<Data, MatchResult>::Match(RequestData *rdata, MatchResult *result)
   bool r;
 
   // Check to see if there is any work to do before makeing
-  //   the stirng copy
+  //   the string copy
   if (num_el <= 0) {
     return;
   }
@@ -969,7 +969,7 @@ ControlMatcher<Data, MatchResult>::BuildTable()
  *         when this file changes.
  *
  *         Also, does not give error messages about template
- *           compliation problems.  Requires the -verbose=template
+ *           compilation problems.  Requires the -verbose=template
  *           flage to error messages
  *
  *  g++: Requires instantiation to occur in the same file as the
diff --git a/proxy/IPAllow.h b/proxy/IPAllow.h
index 112d977..f36edab 100644
--- a/proxy/IPAllow.h
+++ b/proxy/IPAllow.h
@@ -23,7 +23,7 @@
 
 /*****************************************************************************
  *
- *  IPAllow.h - Interface to IP Access Control systtem
+ *  IPAllow.h - Interface to IP Access Control system
  *
  *
  ****************************************************************************/
diff --git a/proxy/ParentSelection.cc b/proxy/ParentSelection.cc
index fd3fef3..c9527c6 100644
--- a/proxy/ParentSelection.cc
+++ b/proxy/ParentSelection.cc
@@ -1542,7 +1542,7 @@ EXCLUSIVE_REGRESSION_TEST(PARENTSELECTION)(RegressionTest * /* t ATS_UNUSED */,
   FP;
   RE(verify(result, PARENT_SPECIFIED, "frisky", 80), 190);
 
-  // now set the host staus on fuzzy to up and it should now
+  // now set the host status on fuzzy to up and it should now
   // be retried.
   _st.setHostStatus("fuzzy", HOST_STATUS_UP, 0, Reason::MANUAL);
   ST(191);
diff --git a/proxy/ParentSelection.h b/proxy/ParentSelection.h
index c0f3802..719b473 100644
--- a/proxy/ParentSelection.h
+++ b/proxy/ParentSelection.h
@@ -91,7 +91,7 @@ private:
 
 // struct pRecord
 //
-//    A record for an invidual parent
+//    A record for an individual parent
 //
 struct pRecord : ATSConsistentHashNode {
   char hostname[MAXDNAME + 1];
diff --git a/proxy/PluginVC.h b/proxy/PluginVC.h
index 6ee6b4d..118a31a 100644
--- a/proxy/PluginVC.h
+++ b/proxy/PluginVC.h
@@ -97,7 +97,7 @@ public:
   ink_hrtime get_active_timeout() override;
   ink_hrtime get_inactivity_timeout() override;
 
-  // Pure virutal functions we need to compile
+  // Pure virtual functions we need to compile
   SOCKET get_socket() override;
   void set_local_addr() override;
   void set_remote_addr() override;
diff --git a/proxy/hdrs/HdrHeap.cc b/proxy/hdrs/HdrHeap.cc
index 5dfd44d..2f1fc0e 100644
--- a/proxy/hdrs/HdrHeap.cc
+++ b/proxy/hdrs/HdrHeap.cc
@@ -845,7 +845,7 @@ HdrHeap::check_marshalled(uint32_t buf_length)
 //
 //   Takes a marshalled representation and swizzles offsets
 //     so they become live pointers and make the heap usable.
-//     Sets *found_obj to first occurance of object of
+//     Sets *found_obj to first occurrence of object of
 //     type obj_type in the heap
 //
 //   Return value is the number of bytes unmarshalled or -1
@@ -1245,7 +1245,7 @@ REGRESSION_TEST(HdrHeap_Coalesce)(RegressionTest *t, int /* atype ATS_UNUSED */,
   // copied the above string onto the heap. The new behaviour fixed in TS-2766 will make sure that this non copied
   // string is accounted for, in the old implementation it would result in an allocation failure.
 
-  char *str = heap->allocate_str(1); // this will force a coalese.
+  char *str = heap->allocate_str(1); // this will force a coalesce.
   tb.check(str != nullptr, "Checking that 1 byte allocated string is not NULL");
 
   // Now we need to validate that aliased_str_url has a path that isn't NULL, if it's NULL then the
diff --git a/proxy/hdrs/HdrHeap.h b/proxy/hdrs/HdrHeap.h
index 825d19c..e7c075c 100644
--- a/proxy/hdrs/HdrHeap.h
+++ b/proxy/hdrs/HdrHeap.h
@@ -47,7 +47,7 @@ static constexpr size_t HDR_PTR_ALIGNMENT_MASK = HDR_PTR_SIZE - 1L;
 using HdrHeapMarshalBlocks                     = ts::Scalar<HDR_PTR_SIZE>;
 
 // A many of the operations regarding read-only str
-//  heaps are hand unrolled in the code.  Chaning
+//  heaps are hand unrolled in the code.  Changing
 //  this value requires a full pass through HdrBuf.cc
 //  to fix the unrolled operations
 static constexpr unsigned HDR_BUF_RONLY_HEAPS = 3;
@@ -203,7 +203,7 @@ public:
   void set_ronly_str_heap_end(int slot, const char *end);
 
   // Lock read only str heaps so that can't be moved around
-  //  by a heap consolidation.  Does NOT lock for Multi-Threaed
+  //  by a heap consolidation.  Does NOT lock for Multi-Threaded
   //  access!
   void
   lock_ronly_str_heap(unsigned i)
diff --git a/proxy/hdrs/HdrToken.h b/proxy/hdrs/HdrToken.h
index 8a50a16..0368052 100644
--- a/proxy/hdrs/HdrToken.h
+++ b/proxy/hdrs/HdrToken.h
@@ -137,7 +137,7 @@ hdrtoken_is_valid_wks_idx(int wks_idx)
 /*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 
-// ToDo: This, and dependencies / users should probalby be const HdrTokenHeapPrefix * IMO.
+// ToDo: This, and dependencies / users should probably be const HdrTokenHeapPrefix * IMO.
 inline HdrTokenHeapPrefix *
 hdrtoken_wks_to_prefix(const char *wks)
 {
@@ -299,7 +299,7 @@ hdrtoken_wks_to_flags(const char *wks)
 ////////////////////////////////////////////////////////////////////////////
 
 // Windows insists on doing everything it's own completely
-//   inmcompatible way, including integer constant subscripts.
+//   incompatible way, including integer constant subscripts.
 //   It's too easy to match a subscript to a type since everything
 //   won't break if the type is a different size.  Oh no, we
 //   need to define the number of bits in our constants to make
diff --git a/proxy/hdrs/HttpCompat.cc b/proxy/hdrs/HttpCompat.cc
index 7502ed0..718b019 100644
--- a/proxy/hdrs/HttpCompat.cc
+++ b/proxy/hdrs/HttpCompat.cc
@@ -579,7 +579,7 @@ HttpCompat::match_accept_language(const char *lang_str, int lang_len, StrList *a
     }
 
     /////////////////////////////////////////////////////////////////////
-    // This algorithm is a bit wierd --- the resulting Q factor is     //
+    // This algorithm is a bit weird --- the resulting Q factor is     //
     // the Q value corresponding to the LONGEST range field that       //
     // matched, or if none matched, then the Q value of any asterisk.  //
     // Also, if the lang value is "", meaning that no Content-Language //
diff --git a/proxy/hdrs/MIME.cc b/proxy/hdrs/MIME.cc
index 73d5b2b..7033b7e 100644
--- a/proxy/hdrs/MIME.cc
+++ b/proxy/hdrs/MIME.cc
@@ -3387,7 +3387,7 @@ mime_parse_date(const char *buf, const char *end)
       if (!mime_parse_time(buf, end, &tp.tm_hour, &tp.tm_min, &tp.tm_sec)) {
         return (time_t)0;
       }
-      // ignore timezone specifier...should always be GMT anways
+      // ignore timezone specifier...should always be GMT anyways
     } else {
       // ANSI C's asctime format
       if (!mime_parse_month(buf, end, &tp.tm_mon)) {
diff --git a/proxy/http/ForwardedConfig.cc b/proxy/http/ForwardedConfig.cc
index 09caffc..c38bb27 100644
--- a/proxy/http/ForwardedConfig.cc
+++ b/proxy/http/ForwardedConfig.cc
@@ -35,7 +35,7 @@ namespace
 class BadOptionsErrMsg
 {
 public:
-  // Construct with referece to string that will contain error message.
+  // Construct with reference to string that will contain error message.
   //
   BadOptionsErrMsg(ts::FixedBufferWriter &err) : _err(err), _count(0) {}
 
diff --git a/proxy/http/Http1ClientSession.cc b/proxy/http/Http1ClientSession.cc
index 10ac26c..d2239ab 100644
--- a/proxy/http/Http1ClientSession.cc
+++ b/proxy/http/Http1ClientSession.cc
@@ -276,7 +276,7 @@ Http1ClientSession::do_io_close(int alerrno)
 
     if (client_vc) {
       // We want the client to know that that we're finished
-      //  writing.  The write shutdown accomplishes this.  Unfortuantely,
+      //  writing.  The write shutdown accomplishes this.  Unfortunately,
       //  the IO Core semantics don't stop us from getting events
       //  on the write side of the connection like timeouts so we
       //  need to zero out the write of the continuation with
diff --git a/proxy/http/Http1ClientTransaction.cc b/proxy/http/Http1ClientTransaction.cc
index d8a78ab..72e4918 100644
--- a/proxy/http/Http1ClientTransaction.cc
+++ b/proxy/http/Http1ClientTransaction.cc
@@ -29,7 +29,7 @@ void
 Http1ClientTransaction::release(IOBufferReader *r)
 {
   // Must set this inactivity count here rather than in the session because the state machine
-  // is not availble then
+  // is not available then
   MgmtInt ka_in = current_reader->t_state.txn_conf->keep_alive_no_activity_timeout_in;
   set_inactivity_timeout(HRTIME_SECONDS(ka_in));
 
diff --git a/proxy/http/HttpBodyFactory.h b/proxy/http/HttpBodyFactory.h
index 165b240..3e2f103 100644
--- a/proxy/http/HttpBodyFactory.h
+++ b/proxy/http/HttpBodyFactory.h
@@ -33,7 +33,7 @@
   The HttpBodyFactory can build a message body for each response type.
   The user can create custom message body text for each type (stored
   in a text file directory), containing templates with space-holders for
-  variables which are inline-substituted with curent values.  The resulting
+  variables which are inline-substituted with current values.  The resulting
   body is dynamically allocated and returned.
 
   The major data types implemented in this file are:
diff --git a/proxy/http/HttpCacheSM.cc b/proxy/http/HttpCacheSM.cc
index 8a859f0..d6a9c26 100644
--- a/proxy/http/HttpCacheSM.cc
+++ b/proxy/http/HttpCacheSM.cc
@@ -269,7 +269,7 @@ HttpCacheSM::open_read(const HttpCacheKey *key, URL *url, HTTPHdr *hdr, Overrida
   current_lookup_level++;
   open_read_cb = false;
   act_return   = do_cache_open_read(cache_key);
-  // the following logic is based on the assumption that the secnod
+  // the following logic is based on the assumption that the second
   // lookup won't happen if the HttpSM hasn't been called back for the
   // first lookup
   if (current_lookup_level == lookup_max_recursive) {
diff --git a/proxy/http/HttpConfig.h b/proxy/http/HttpConfig.h
index 0bb0a35..c24ac05 100644
--- a/proxy/http/HttpConfig.h
+++ b/proxy/http/HttpConfig.h
@@ -73,7 +73,7 @@ enum {
 
   // Http Total Connections Stats
   //
-  // it is assumed that this inequality will always be satisifed:
+  // it is assumed that this inequality will always be satisfied:
   //   http_total_client_connections_stat >=
   //     http_total_client_connections_ipv4_stat +
   //     http_total_client_connections_ipv6_stat
diff --git a/proxy/http/HttpConnectionCount.h b/proxy/http/HttpConnectionCount.h
index 2d4efdd..4e6b2b2 100644
--- a/proxy/http/HttpConnectionCount.h
+++ b/proxy/http/HttpConnectionCount.h
@@ -43,7 +43,7 @@
 #include "Show.h"
 
 /**
- * Singleton class to keep track of the number of outbound connnections.
+ * Singleton class to keep track of the number of outbound connections.
  *
  * Outbound connections are divided in to equivalence classes (called "groups" here) based on the
  * session matching setting. Tracking data is stored for each group.
@@ -227,7 +227,7 @@ public:
    */
   static void config_init(GlobalConfig *global, TxnConfig *txn);
 
-  /// Tag used for debugging otuput.
+  /// Tag used for debugging output.
   static constexpr char const *const DEBUG_TAG{"conn_track"};
 
   /** Convert a string to a match type.
diff --git a/proxy/http/HttpPages.cc b/proxy/http/HttpPages.cc
index a4d0683..ab0b702 100644
--- a/proxy/http/HttpPages.cc
+++ b/proxy/http/HttpPages.cc
@@ -26,7 +26,7 @@
    HttpPages.cc
 
    Description:
-       Data structurs and stat page generators for http info
+       Data structures and stat page generators for http info
 
 
  ****************************************************************************/
diff --git a/proxy/http/HttpPages.h b/proxy/http/HttpPages.h
index 7b9fea2..286dc00 100644
--- a/proxy/http/HttpPages.h
+++ b/proxy/http/HttpPages.h
@@ -26,7 +26,7 @@
    HttpPages.h
 
    Description:
-       Data structurs and stat page generators for http info
+       Data structures and stat page generators for http info
 
 
  ****************************************************************************/
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index 61cc4fe..8f1d13e 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -1600,8 +1600,8 @@ HttpSM::handle_api_return()
 
     // We only follow 3xx when redirect_in_process == false. Otherwise the redirection has already been launched (in
     // SM_ACTION_SERVER_READ).redirect_in_process is set before this logic if we need more direction.
-    // This redirection is only used with the build_error_reponse. Then, the redirection_tries will be increased by
-    // state_read_server_reponse_header and never get into this logic again.
+    // This redirection is only used with the build_error_response. Then, the redirection_tries will be increased by
+    // state_read_server_response_header and never get into this logic again.
     if (enable_redirection && !t_state.redirect_info.redirect_in_process && is_redirect_required()) {
       do_redirect();
     }
@@ -7967,7 +7967,7 @@ HttpSM::is_redirect_required()
 
   if (redirect_required == true) {
     HTTPStatus status = t_state.hdr_info.client_response.status_get();
-    // check to see if the response from the orgin was a 301, 302, or 303
+    // check to see if the response from the origin was a 301, 302, or 303
     switch (status) {
     case HTTP_STATUS_MULTIPLE_CHOICES:   // 300
     case HTTP_STATUS_MOVED_PERMANENTLY:  // 301
diff --git a/proxy/http/HttpSM.h b/proxy/http/HttpSM.h
index fe31729..ed1b140 100644
--- a/proxy/http/HttpSM.h
+++ b/proxy/http/HttpSM.h
@@ -266,7 +266,7 @@ public:
   VConnection *do_transform_open();
   VConnection *do_post_transform_open();
 
-  // Called by transact(HttpTransact::is_request_retryable), temperarily.
+  // Called by transact(HttpTransact::is_request_retryable), temporarily.
   // This function should be remove after #1994 fixed.
   bool
   is_post_transform_request()
@@ -323,7 +323,7 @@ public:
 
   HttpTransact::State t_state;
 
-  // This unfortunately can't go into the t_state, beacuse of circular dependencies. We could perhaps refactor
+  // This unfortunately can't go into the t_state, because of circular dependencies. We could perhaps refactor
   // this, with a lot of work, but this is easier for now.
   UrlRewrite *m_remap = nullptr;
 
diff --git a/proxy/http/HttpServerSession.h b/proxy/http/HttpServerSession.h
index 03ff015..9e4ffcc 100644
--- a/proxy/http/HttpServerSession.h
+++ b/proxy/http/HttpServerSession.h
@@ -119,7 +119,7 @@ public:
   HSS_State state    = HSS_INIT;
 
   // Used to determine whether the session is for parent proxy
-  // it is session to orgin server
+  // it is session to origin server
   // We need to determine whether a closed connection was to
   // close parent proxy to update the
   // proxy.process.http.current_parent_proxy_connections
@@ -175,7 +175,7 @@ public:
   //   to being acquired and parsing the header without
   //   changing the buffer we are doing I/O on.  We can
   //   not change the buffer for I/O without issuing a
-  //   an asyncronous cancel on NT
+  //   an asynchronous cancel on NT
   MIOBuffer *read_buffer = nullptr;
 
   virtual int
diff --git a/proxy/http/HttpTransact.cc b/proxy/http/HttpTransact.cc
index ed30844..59de07b 100644
--- a/proxy/http/HttpTransact.cc
+++ b/proxy/http/HttpTransact.cc
@@ -2846,7 +2846,7 @@ HttpTransact::build_response_from_cache(State *s, HTTPWarningCode warning_code)
       s->next_action       = SM_ACTION_INTERNAL_CACHE_NOOP;
     } else {
       // We handled the request but it's not GET or HEAD (eg. DELETE),
-      // and server is not reacheable: 502
+      // and server is not reachable: 502
       //
       TxnDebug("http_trans", "[build_response_from_cache] No match! Connection failed.");
       build_error_response(s, HTTP_STATUS_BAD_GATEWAY, "Connection Failed", "connect#failed_connect");
@@ -4796,7 +4796,7 @@ HttpTransact::merge_response_header_with_cached_header(HTTPHdr *cached_header, H
     //   can't do this because what is already there
     //   may be a dup we've already copied in.  If
     //   dups show up we look through the remaining
-    //   header fields in the new reponse, nuke
+    //   header fields in the new response, nuke
     //   them in the cached response and then add in
     //   the remaining fields one by one from the
     //   response header
@@ -4853,7 +4853,7 @@ HttpTransact::merge_warning_header(HTTPHdr *cached_header, HTTPHdr *response_hea
   //         header, they need to be removed.  Removal
   //         is difficult since the hdrs don't comma
   //         separate values, so build up a new header
-  //         piecemal.  Very slow but shouldn't happen
+  //         piecemeal.  Very slow but shouldn't happen
   //         very often
   //    3) Since we keep the all the warning codes from
   //         the response header, append if to
@@ -5396,7 +5396,7 @@ HttpTransact::handle_trace_and_options_requests(State *s, HTTPHdr *incoming_hdr)
   } else { /* max-forwards != 0 */
 
     // Logically want to make sure max_forwards is a legitimate non-zero non-negative integer
-    // Since max_fowards is a signed integer, no sense making sure it is less than INT_MAX.
+    // Since max_forwards is a signed integer, no sense making sure it is less than INT_MAX.
     // Would be negative in that case.  Already checked negative in the other case.  Noted by coverity
 
     --max_forwards;
@@ -6038,7 +6038,7 @@ HttpTransact::is_response_cacheable(State *s, HTTPHdr *request, HTTPHdr *respons
   // TxnDebug("http_trans", "[is_response_cacheable] server permits storing");
 
   // does config explicitly forbid storing?
-  // ttl overides other config parameters
+  // ttl overrides other config parameters
   if ((!s->cache_info.directives.does_config_permit_storing && (s->cache_control.ttl_in_cache <= 0)) ||
       (s->cache_control.never_cache)) {
     TxnDebug("http_trans", "[is_response_cacheable] config doesn't allow storing, and cache control does not "
@@ -6753,7 +6753,7 @@ HttpTransact::handle_request_keep_alive_headers(State *s, HTTPVersion ver, HTTPH
         }
       }
       // Note: if we are 1.1, we always need to send the close
-      //  header since persistant connnections are the default
+      //  header since persistent connections are the default
       break;
     default:
       ink_assert(0);
@@ -6913,7 +6913,7 @@ HttpTransact::handle_response_keep_alive_headers(State *s, HTTPVersion ver, HTTP
       s->client_info.keep_alive = HTTP_NO_KEEPALIVE;
     }
     // Note: if we are 1.1, we always need to send the close
-    //  header since persistant connnections are the default
+    //  header since persistent connections are the default
     break;
   default:
     ink_assert(0);
@@ -7565,7 +7565,7 @@ HttpTransact::build_request(State *s, HTTPHdr *base_request, HTTPHdr *outgoing_r
       }
     }
 
-    // Peform any configured normalization (including per-remap-rule configuration overrides) of the Accept-Encoding header
+    // Perform any configured normalization (including per-remap-rule configuration overrides) of the Accept-Encoding header
     // field (if any).  This has to be done in the request from the client, for the benefit of the gzip plugin.
     //
     HttpTransactHeaders::normalize_accept_encoding(s->txn_conf, base_request);
@@ -7579,7 +7579,7 @@ HttpTransact::build_request(State *s, HTTPHdr *base_request, HTTPHdr *outgoing_r
   handle_request_keep_alive_headers(s, outgoing_version, outgoing_request);
 
   // handle_conditional_headers appears to be obsolete.  Nothing happens
-  // unelss s->cache_info.action == HttpTransact::CACHE_DO_UPDATE.  In that
+  // unless s->cache_info.action == HttpTransact::CACHE_DO_UPDATE.  In that
   // case an assert will go off.  The functionality of this method
   // (e.g., setting the if-modfied-since header occurs in issue_revalidate
   // HttpTransactHeaders::handle_conditional_headers(&s->cache_info, outgoing_request);
@@ -7866,7 +7866,7 @@ HttpTransact::build_error_response(State *s, HTTPStatus status_code, const char
     error_body_type = "default";
   }
 
-  // Make sure that if this error occurred before we initailzied the state variables that we do now.
+  // Make sure that if this error occurred before we initialized the state variables that we do now.
   initialize_state_variables_from_request(s, &s->hdr_info.client_request);
 
   //////////////////////////////////////////////////////
diff --git a/proxy/http/HttpTransactCache.cc b/proxy/http/HttpTransactCache.cc
index 56adb7b..cdff3f9 100644
--- a/proxy/http/HttpTransactCache.cc
+++ b/proxy/http/HttpTransactCache.cc
@@ -880,7 +880,7 @@ HttpTransactCache::calculate_quality_of_accept_encoding_match(MIMEField *accept_
   //   The 1.1 spec says servers MAY assume that clients will accept   //
   //   any encoding if no header is sent.  Unforntunately, this does   //
   //   not work 1.0 clients & is particularly thorny when the proxy    //
-  //   created the enconding as the result of a transform.  Http 1.1   //
+  //   created the encoding as the result of a transform.  Http 1.1   //
   //   purists would say that if proxy encodes something it's really   //
   //   a transfer-encoding and not a content-encoding but again this   //
   //   causes problems with 1.0 clients                                //
@@ -1015,7 +1015,7 @@ match_accept_content_language(const char *c_raw, MIMEField *accept_field, bool *
     float tq = HttpCompat::find_Q_param_in_strlist(&a_param_list);
 
     /////////////////////////////////////////////////////////////////////
-    // This algorithm is a bit wierd --- the resulting Q factor is     //
+    // This algorithm is a bit weird --- the resulting Q factor is     //
     // the Q value corresponding to the LONGEST range field that       //
     // matched, or if none matched, then the Q value of any asterisk.  //
     // Also, if the lang value is "", meaning that no Content-Language //
@@ -1048,7 +1048,7 @@ match_accept_content_language(const char *c_raw, MIMEField *accept_field, bool *
 }
 
 // FIX: This code is icky, and i suspect wrong in places, particularly
-//      beacuse parts of match_accept_content_language are commented out.
+//      because parts of match_accept_content_language are commented out.
 //      It looks like lots of hacks were done.  The code should probably
 //      be updated to use the code in HttpCompat::match_accept_language.
 
diff --git a/proxy/http/HttpTransactHeaders.cc b/proxy/http/HttpTransactHeaders.cc
index 5f18843..22a9da6 100644
--- a/proxy/http/HttpTransactHeaders.cc
+++ b/proxy/http/HttpTransactHeaders.cc
@@ -217,7 +217,7 @@ HttpTransactHeaders::copy_header_fields(HTTPHdr *src_hdr, HTTPHdr *new_hdr, bool
   //         we'll have problems with the TE being forwarded to the server
   //         and us caching the transfer encoded documents and then
   //         serving it to a client that can not handle it
-  //      2) Transfer enconding is copied.  If the transfer encoding
+  //      2) Transfer encoding is copied.  If the transfer encoding
   //         is changed for example by dechunking, the transfer encoding
   //         should be modified when when the decision is made to dechunk it
 
diff --git a/proxy/http/HttpTunnel.cc b/proxy/http/HttpTunnel.cc
index 8e37e72..9ca6817 100644
--- a/proxy/http/HttpTunnel.cc
+++ b/proxy/http/HttpTunnel.cc
@@ -613,7 +613,7 @@ HttpTunnel::add_producer(VConnection *vc, int64_t nbytes_arg, IOBufferReader *re
     if (p->nbytes < 0) {
       p->ntodo = p->nbytes;
     } else { // The byte count given us includes bytes
-      //  that alread may be in the buffer.
+      //  that already may be in the buffer.
       //  ntodo represents the number of bytes
       //  the tunneling mechanism needs to read
       //  for the producer
@@ -1330,7 +1330,7 @@ HttpTunnel::consumer_handler(int event, HttpTunnelConsumer *c)
     }
 
     // Since we removed a consumer, it may now be
-    //   possbile to put more stuff in the buffer
+    //   possible to put more stuff in the buffer
     // Note: we reenable only after calling back
     //    the SM since the reenabling has the side effect
     //    updating the buffer state for the VConnection
diff --git a/proxy/http2/Http2ConnectionState.cc b/proxy/http2/Http2ConnectionState.cc
index afc1d24..8145bb3 100644
--- a/proxy/http2/Http2ConnectionState.cc
+++ b/proxy/http2/Http2ConnectionState.cc
@@ -382,7 +382,7 @@ rcv_priority_frame(Http2ConnectionState &cstate, const Http2Frame &frame)
   Http2StreamDebug(cstate.ua_session, stream_id, "Received PRIORITY frame");
 
   if (cstate.get_zombie_event()) {
-    Warning("Priority frame for zombied sessoin %" PRId64, cstate.ua_session->connection_id());
+    Warning("Priority frame for zombied session %" PRId64, cstate.ua_session->connection_id());
   }
 
   // If a PRIORITY frame is received with a stream identifier of 0x0, the
@@ -516,7 +516,7 @@ rcv_settings_frame(Http2ConnectionState &cstate, const Http2Frame &frame)
   Http2StreamDebug(cstate.ua_session, stream_id, "Received SETTINGS frame");
 
   if (cstate.get_zombie_event()) {
-    Warning("Setting frame for zombied sessoin %" PRId64, cstate.ua_session->connection_id());
+    Warning("Setting frame for zombied session %" PRId64, cstate.ua_session->connection_id());
   }
 
   // [RFC 7540] 6.5. The stream identifier for a SETTINGS frame MUST be zero.
diff --git a/proxy/http2/Http2ConnectionState.h b/proxy/http2/Http2ConnectionState.h
index 57cd368..0b8722c 100644
--- a/proxy/http2/Http2ConnectionState.h
+++ b/proxy/http2/Http2ConnectionState.h
@@ -328,7 +328,7 @@ private:
   // Counter for current active streams which is started by client
   std::atomic<uint32_t> client_streams_in_count = 0;
 
-  // Counter for current acive streams which is started by server
+  // Counter for current active streams which is started by server
   std::atomic<uint32_t> client_streams_out_count = 0;
 
   // Counter for current active streams and streams in the process of shutting down
diff --git a/proxy/http2/Http2Stream.h b/proxy/http2/Http2Stream.h
index 71fc00d..25df6b5 100644
--- a/proxy/http2/Http2Stream.h
+++ b/proxy/http2/Http2Stream.h
@@ -254,13 +254,13 @@ private:
   bool body_done       = false;
   bool chunked         = false;
 
-  // A brief disucssion of similar flags and state variables:  _state, closed, terminate_stream
+  // A brief discussion of similar flags and state variables:  _state, closed, terminate_stream
   //
   // _state tracks the HTTP2 state of the stream.  This field completely coincides with the H2 spec.
   //
   // closed is a flag that gets set when the framework indicates that the stream should be shutdown.  This flag
   // is set from either do_io_close, which indicates that the HttpSM is starting the close, or initiating_close,
-  // which indicates that the HTTP2 infrastructure is starting the close (e.g. due to the HTTP2 session shuttig down
+  // which indicates that the HTTP2 infrastructure is starting the close (e.g. due to the HTTP2 session shutting down
   // or a end of stream frame being received.  The closed flag does not indicate that it is safe to delete the stream
   // immediately. Perhaps the closed flag could be folded into the _state field.
   //
diff --git a/proxy/logging/LogAccess.cc b/proxy/logging/LogAccess.cc
index 43e5c75..d673068 100644
--- a/proxy/logging/LogAccess.cc
+++ b/proxy/logging/LogAccess.cc
@@ -479,7 +479,7 @@ LogAccess::unmarshal_int(char **buf)
   ink_assert(*buf != nullptr);
   int64_t val;
 
-  // TODO: this used to do nthol, do we need to worrry? TS-1156.
+  // TODO: this used to do nthol, do we need to worry? TS-1156.
   val = *((int64_t *)(*buf));
   *buf += INK_MIN_ALIGN;
   return val;
@@ -1788,7 +1788,7 @@ LogAccess::marshal_client_req_uuid(char *buf)
   len = round_strlen(len + 1);
 
   if (buf) {
-    marshal_str(buf, str, len); // This will pad the remaning bytes properly ...
+    marshal_str(buf, str, len); // This will pad the remaining bytes properly ...
   }
 
   return len;
diff --git a/proxy/logging/LogFile.cc b/proxy/logging/LogFile.cc
index 3f9a581..53b0275 100644
--- a/proxy/logging/LogFile.cc
+++ b/proxy/logging/LogFile.cc
@@ -590,7 +590,7 @@ LogFile::check_fd()
     //
     // It's time to see if the file really exists.  If we can't see
     // the file (via access), then we'll close our descriptor and
-    // attept to re-open it, which will create the file if it's not
+    // attempt to re-open it, which will create the file if it's not
     // there.
     //
     if (m_name && !LogFile::exists(m_name)) {
diff --git a/proxy/logging/LogFilter.h b/proxy/logging/LogFilter.h
index 94d5ff7..4fe7c8e 100644
--- a/proxy/logging/LogFilter.h
+++ b/proxy/logging/LogFilter.h
@@ -383,7 +383,7 @@ LogFilterString::_checkCondition(OperatorFunction f, const char *field_value, si
 }
 
 /*---------------------------------------------------------------------------
-  wipeField : Given a dest buffer, wipe the first occurance of the value of the
+  wipeField : Given a dest buffer, wipe the first occurrence of the value of the
   field in the buffer.
 
 --------------------------------------------------------------------------*/
diff --git a/proxy/logging/LogFormat.cc b/proxy/logging/LogFormat.cc
index e87e154..2446437 100644
--- a/proxy/logging/LogFormat.cc
+++ b/proxy/logging/LogFormat.cc
@@ -543,11 +543,11 @@ LogFormat::parse_symbol_string(const char *symbol_string, LogFieldList *field_li
 // 1) Octal representation: '\abc', for example: '\060'
 //    0 < (a*8^2 + b*8 + c) < 255
 //
-// 2) Hex representation: '\xab', for exampe: '\x3A'
+// 2) Hex representation: '\xab', for example: '\x3A'
 //    0 < (a*16 + b) < 255
 //
 // Return -1 if the beginning four characters are not valid
-// escape sequence, otherwise reutrn unsigned char value of the
+// escape sequence, otherwise return unsigned char value of the
 // escape sequence in the string.
 //
 // NOTE: The value of escape sequence should be greater than 0
diff --git a/proxy/logging/LogObject.cc b/proxy/logging/LogObject.cc
index cb91f5b..74b45dd 100644
--- a/proxy/logging/LogObject.cc
+++ b/proxy/logging/LogObject.cc
@@ -285,7 +285,7 @@ LogObject::set_filter_list(const LogFilterList &list, bool copy)
   m_filter_list.set_conjunction(list.does_conjunction());
 }
 
-// we conpute the object signature from the fieldlist_str and the printf_str
+// we compute the object signature from the fieldlist_str and the printf_str
 // of the LogFormat rather than from the format_str because the format_str
 // is not part of a LogBuffer header
 //
diff --git a/proxy/logging/LogStandalone.cc b/proxy/logging/LogStandalone.cc
index c65185a..b893cc5 100644
--- a/proxy/logging/LogStandalone.cc
+++ b/proxy/logging/LogStandalone.cc
@@ -98,7 +98,7 @@ initialize_process_manager()
 {
   mgmt_use_syslog();
 
-  // Temporary Hack to Enable Communuication with LocalManager
+  // Temporary Hack to Enable Communication with LocalManager
   if (getenv("PROXY_REMOTE_MGMT")) {
     remote_management_flag = true;
   }
diff --git a/proxy/logging/LogUtils.cc b/proxy/logging/LogUtils.cc
index 61f2891..eeb4a93 100644
--- a/proxy/logging/LogUtils.cc
+++ b/proxy/logging/LogUtils.cc
@@ -591,7 +591,7 @@ LogUtils::file_is_writeable(const char *full_filename, off_t *size_bytes, bool *
 
 namespace
 {
-// Get a string out of a MIMEField using one of its member funcitions, and put it into a buffer writer, terminated with a nul.
+// Get a string out of a MIMEField using one of its member functions, and put it into a buffer writer, terminated with a nul.
 //
 void
 marshalStr(ts::FixedBufferWriter &bw, const MIMEField &mf, const char *(MIMEField::*get_func)(int *length) const)
diff --git a/src/traffic_logstats/logstats.cc b/src/traffic_logstats/logstats.cc
index d396c4e..6cace5b 100644
--- a/src/traffic_logstats/logstats.cc
+++ b/src/traffic_logstats/logstats.cc
@@ -634,7 +634,7 @@ static ArgumentDescription argument_descriptions[] = {
   {"log_file", 'f', "Specific logfile to parse", "S1023", cl.log_file, nullptr, nullptr},
   {"origin_list", 'o', "Only show stats for listed Origins", "S4095", cl.origin_list, nullptr, nullptr},
   {"origin_file", 'O', "File listing Origins to show", "S1023", cl.origin_file, nullptr, nullptr},
-  {"max_orgins", 'M', "Max number of Origins to show", "I", &cl.max_origins, nullptr, nullptr},
+  {"max_origins", 'M', "Max number of Origins to show", "I", &cl.max_origins, nullptr, nullptr},
   {"urls", 'u', "Produce JSON stats for URLs, argument is LRU size", "I", &cl.urls, nullptr, nullptr},
   {"show_urls", 'U', "Only show max this number of URLs", "I", &cl.show_urls, nullptr, nullptr},
   {"as_object", 'A', "Produce URL stats as a JSON object instead of array", "T", &cl.as_object, nullptr, nullptr},
diff --git a/tests/gold_tests/autest-site/trafficserver.test.ext b/tests/gold_tests/autest-site/trafficserver.test.ext
index 7ae7626..ed58fa8 100755
--- a/tests/gold_tests/autest-site/trafficserver.test.ext
+++ b/tests/gold_tests/autest-site/trafficserver.test.ext
@@ -98,7 +98,7 @@ def MakeATSProcess(obj, name, command='traffic_server', select_ports=True):
     p.Variables.CONFIGDIR = config_dir
     #########################################################
     # setup read-only data directory in config. Needed for response body
-    # reponses
+    # responses
 
     p.Env['PROXY_CONFIG_BODY_FACTORY_TEMPLATE_SETS_DIR'] = template_dir
     p.Variables.BODY_FACTORY_TEMPLATE_DIR = template_dir
diff --git a/tests/gold_tests/headers/hsts.test.py b/tests/gold_tests/headers/hsts.test.py
index 7ae60e2..3f95f78 100644
--- a/tests/gold_tests/headers/hsts.test.py
+++ b/tests/gold_tests/headers/hsts.test.py
@@ -1,5 +1,5 @@
 '''
-Test the hsts reponse header.
+Test the hsts response header.
 '''
 #  Licensed to the Apache Software Foundation (ASF) under one
 #  or more contributor license agreements.  See the NOTICE file
diff --git a/tests/gold_tests/headers/http408.test.py b/tests/gold_tests/headers/http408.test.py
index 6fe7dc1..8e2c37b 100644
--- a/tests/gold_tests/headers/http408.test.py
+++ b/tests/gold_tests/headers/http408.test.py
@@ -1,5 +1,5 @@
 '''
-Test the 408 reponse header.
+Test the 408 response header.
 '''
 #  Licensed to the Apache Software Foundation (ASF) under one
 #  or more contributor license agreements.  See the NOTICE file