You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by jp...@apache.org on 2012/12/08 20:00:56 UTC

git commit: TS-1615: Some spelling errors in source code

Updated Branches:
  refs/heads/master 0fcc63b2b -> 78b813416


TS-1615: Some spelling errors in source code


Project: http://git-wip-us.apache.org/repos/asf/trafficserver/repo
Commit: http://git-wip-us.apache.org/repos/asf/trafficserver/commit/78b81341
Tree: http://git-wip-us.apache.org/repos/asf/trafficserver/tree/78b81341
Diff: http://git-wip-us.apache.org/repos/asf/trafficserver/diff/78b81341

Branch: refs/heads/master
Commit: 78b813416dc070e15d411839d108c262f4a194fb
Parents: 0fcc63b
Author: Aron Xu <ha...@gmail.com>
Authored: Sat Dec 8 10:58:44 2012 -0800
Committer: James Peach <jp...@apache.org>
Committed: Sat Dec 8 10:58:44 2012 -0800

----------------------------------------------------------------------
 CHANGES                                            |    3 +++
 cop/TrafficCop.cc                                  |    2 +-
 iocore/cluster/ClusterConfig.cc                    |    2 +-
 lib/records/RecHttp.cc                             |    2 +-
 mgmt/api/CoreAPI.cc                                |    2 +-
 mgmt/api/remote/NetworkUtilsRemote.cc              |    2 +-
 mgmt/web2/WebIntrMain.cc                           |    6 +++---
 plugins/conf_remap/conf_remap.cc                   |    2 +-
 plugins/experimental/balancer/balancer.cc          |    2 +-
 .../experimental/channel_stats/channel_stats.cc    |    2 +-
 plugins/experimental/esi/plugin.cc                 |    2 +-
 plugins/experimental/geoip_acl/geoip_acl.cc        |    2 +-
 .../experimental/header_rewrite/header_rewrite.cc  |    2 +-
 plugins/experimental/hipes/hipes.cc                |    2 +-
 .../memcached_remap/memcached_remap.cc             |    2 +-
 plugins/experimental/mysql_remap/mysql_remap.cc    |    2 +-
 plugins/header_filter/header_filter.cc             |    2 +-
 plugins/regex_remap/regex_remap.cc                 |    2 +-
 plugins/stats_over_http/stats_over_http.c          |    2 +-
 proxy/ControlMatcher.cc                            |    4 ++--
 proxy/InkAPITest.cc                                |    2 +-
 proxy/Main.cc                                      |    2 +-
 proxy/hdrs/HTTP.h                                  |    2 +-
 proxy/hdrs/HdrHeap.cc                              |    2 +-
 proxy/http/HttpTransact.cc                         |    2 +-
 proxy/http/HttpTunnel.cc                           |    2 +-
 proxy/logging/Log.h                                |    2 +-
 proxy/logging/LogStandalone.cc                     |    2 +-
 28 files changed, 33 insertions(+), 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/CHANGES
----------------------------------------------------------------------
diff --git a/CHANGES b/CHANGES
index 3d925da..1d54636 100644
--- a/CHANGES
+++ b/CHANGES
@@ -1,6 +1,9 @@
                                                          -*- coding: utf-8 -*-
 Changes with Apache Traffic Server 3.3.1
 
+  *) [TS-1615] Some spelling errors in source code
+    Author: Aron Xu.
+
   *) [TS-1608] IpAllow should use standard config update
 
   *) [TS-1580] Mutex leak plugged.

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/cop/TrafficCop.cc
----------------------------------------------------------------------
diff --git a/cop/TrafficCop.cc b/cop/TrafficCop.cc
index 5817886..6b0a0eb 100644
--- a/cop/TrafficCop.cc
+++ b/cop/TrafficCop.cc
@@ -742,7 +742,7 @@ spawn_manager()
     snprintf(old_log_file, sizeof(old_log_file), "%s.old", log_file);
     // coverity[toctou]
     rename(log_file, old_log_file);
-    cop_log(COP_WARNING, "rename %s to %s as it is not accessable.\n", log_file, old_log_file);
+    cop_log(COP_WARNING, "rename %s to %s as it is not accessible.\n", log_file, old_log_file);
   }
   // coverity[toctou]
   if ((log_fd = open(log_file, O_WRONLY | O_APPEND | O_CREAT, 0640)) < 0) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/iocore/cluster/ClusterConfig.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterConfig.cc b/iocore/cluster/ClusterConfig.cc
index 7516609..06e02e9 100644
--- a/iocore/cluster/ClusterConfig.cc
+++ b/iocore/cluster/ClusterConfig.cc
@@ -283,7 +283,7 @@ free_configuration(ClusterConfiguration * c, ClusterConfiguration * prev)
   // are used in different threads, so reference counts are
   // relatively difficult and expensive.  The solution I have
   // chosen is to simply delete the object after some (very long)
-  // time after it has ceased to be accessable.
+  // time after it has ceased to be accessible.
   //
   eventProcessor.schedule_in(NEW(new ConfigurationContinuation(c, prev)), CLUSTER_CONFIGURATION_TIMEOUT, ET_CALL);
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/lib/records/RecHttp.cc
----------------------------------------------------------------------
diff --git a/lib/records/RecHttp.cc b/lib/records/RecHttp.cc
index 37cecfa..31a6c12 100644
--- a/lib/records/RecHttp.cc
+++ b/lib/records/RecHttp.cc
@@ -358,7 +358,7 @@ HttpProxyPort::processOptions(char const* opts) {
 
   if (af_set_p) {
     if (in_ip_set_p && m_family != m_inbound_ip.family()) {
-      Warning("Invalid port descriptor '%s' - the inbound adddress family [%s] is not the same type as the explict family value [%s]",
+      Warning("Invalid port descriptor '%s' - the inbound adddress family [%s] is not the same type as the explicit family value [%s]",
         opts, ats_ip_family_name(m_inbound_ip.family()), ats_ip_family_name(m_family));
       zret = false;
     }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/mgmt/api/CoreAPI.cc
----------------------------------------------------------------------
diff --git a/mgmt/api/CoreAPI.cc b/mgmt/api/CoreAPI.cc
index 68f4d10..c060d10 100644
--- a/mgmt/api/CoreAPI.cc
+++ b/mgmt/api/CoreAPI.cc
@@ -889,7 +889,7 @@ SnapshotGetMlt(LLQ * snapshots)
  * (type PROCESS, NODE, CLUSTER), sets them back to their default value
  * If one stat fails to be set correctly, then continues onto next one,
  * but will return TS_ERR_FAIL. Only returns TS_ERR_OKAY if all
- * stats are set back to defaults succesfully.
+ * stats are set back to defaults successfully.
  */
 TSError
 StatsReset(bool cluster)

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/mgmt/api/remote/NetworkUtilsRemote.cc
----------------------------------------------------------------------
diff --git a/mgmt/api/remote/NetworkUtilsRemote.cc b/mgmt/api/remote/NetworkUtilsRemote.cc
index 0dc809a..2da4fc6 100644
--- a/mgmt/api/remote/NetworkUtilsRemote.cc
+++ b/mgmt/api/remote/NetworkUtilsRemote.cc
@@ -285,7 +285,7 @@ reconnect()
  * purpose: attempts to reconnect to TM (eg. when TM restarts) for the
  *          specified number of times
  * input:  num_attempts - number of reconnection attempts to try before quit
- * output: TS_ERR_OKAY - if succesfully reconnected within num_attempts
+ * output: TS_ERR_OKAY - if successfully reconnected within num_attempts
  *         TS_ERR_xx - the reason the reconnection failed
  * notes:
  ***************************************************************************/

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/mgmt/web2/WebIntrMain.cc
----------------------------------------------------------------------
diff --git a/mgmt/web2/WebIntrMain.cc b/mgmt/web2/WebIntrMain.cc
index 210a1df..f0b6a10 100644
--- a/mgmt/web2/WebIntrMain.cc
+++ b/mgmt/web2/WebIntrMain.cc
@@ -342,7 +342,7 @@ webIntr_main(void *x)
 #endif
   char pacFailMsg[] = "Auto-Configuration Service Failed to Initialize";
   //  char gphFailMsg[] = "Dynamic Graph Service Failed to Initialize";
-  char mgmtapiFailMsg[] = "Traffic server managment API service Interface Failed to Initialize.";
+  char mgmtapiFailMsg[] = "Traffic server management API service Interface Failed to Initialize.";
 
   RecInt tempInt;
   bool found;
@@ -444,14 +444,14 @@ webIntr_main(void *x)
   // INKqa12562: MgmtAPI sockets should be created with 775 permission
   mode_t oldmask = umask(S_IWOTH);
   if ((mgmtapiFD = newUNIXsocket(api_sock_path)) < 0) {
-    mgmt_log(stderr, "[WebIntrMain] Unable to set up socket for handling managment API calls. API socket path = %s\n",
+    mgmt_log(stderr, "[WebIntrMain] Unable to set up socket for handling management API calls. API socket path = %s\n",
              api_sock_path);
     lmgmt->alarm_keeper->signalAlarm(MGMT_ALARM_WEB_ERROR, mgmtapiFailMsg);
   }
 
   if ((eventapiFD = newUNIXsocket(event_sock_path)) < 0) {
     mgmt_log(stderr,
-             "[WebIntrMain] Unable to set up so for handling managment API event calls. Event Socket path: %s\n",
+             "[WebIntrMain] Unable to set up so for handling management API event calls. Event Socket path: %s\n",
              event_sock_path);
   }
   umask(oldmask);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/conf_remap/conf_remap.cc
----------------------------------------------------------------------
diff --git a/plugins/conf_remap/conf_remap.cc b/plugins/conf_remap/conf_remap.cc
index 11d2a97..c9f5e35 100644
--- a/plugins/conf_remap/conf_remap.cc
+++ b/plugins/conf_remap/conf_remap.cc
@@ -191,7 +191,7 @@ TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
     return TS_ERROR;
   }
 
-  TSDebug(PLUGIN_NAME, "remap plugin is succesfully initialized");
+  TSDebug(PLUGIN_NAME, "remap plugin is successfully initialized");
   return TS_SUCCESS;                     /* success */
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/balancer/balancer.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/balancer/balancer.cc b/plugins/experimental/balancer/balancer.cc
index 40f8290..adc91ad 100644
--- a/plugins/experimental/balancer/balancer.cc
+++ b/plugins/experimental/balancer/balancer.cc
@@ -208,7 +208,7 @@ tsremap_init(TSREMAP_INTERFACE *api_info, char *errbuf, int errbuf_size)
     return -3;
   }
 
-  TSDebug("balancer", "plugin is succesfully initialized");
+  TSDebug("balancer", "plugin is successfully initialized");
   return 0;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/channel_stats/channel_stats.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/channel_stats/channel_stats.cc b/plugins/experimental/channel_stats/channel_stats.cc
index 3d8aaac..39e9095 100644
--- a/plugins/experimental/channel_stats/channel_stats.cc
+++ b/plugins/experimental/channel_stats/channel_stats.cc
@@ -587,7 +587,7 @@ json_out_stat(TSRecordType rec_type, void *edata, int registered,
   case TS_RECORDDATATYPE_STRING:
     APPEND_STAT(name, "%s", datum->rec_string); break;
   default:
-    debug_api("unkown type for %s: %d", name, data_type);
+    debug_api("unknown type for %s: %d", name, data_type);
     break;
   }
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/esi/plugin.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/plugin.cc b/plugins/experimental/esi/plugin.cc
index 1c21172..4b89623 100644
--- a/plugins/experimental/esi/plugin.cc
+++ b/plugins/experimental/esi/plugin.cc
@@ -1609,7 +1609,7 @@ TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
     return TS_ERROR;
   }
 
-  TSDebug(DEBUG_TAG, "esi remap plugin is succesfully initialized");
+  TSDebug(DEBUG_TAG, "esi remap plugin is successfully initialized");
   return TS_SUCCESS;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/geoip_acl/geoip_acl.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/geoip_acl/geoip_acl.cc b/plugins/experimental/geoip_acl/geoip_acl.cc
index c016a4c..efd41a3 100644
--- a/plugins/experimental/geoip_acl/geoip_acl.cc
+++ b/plugins/experimental/geoip_acl/geoip_acl.cc
@@ -52,7 +52,7 @@ TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
   gGI = GeoIP_new(GEOIP_MMAP_CACHE);
 #endif
 
-  TSDebug(PLUGIN_NAME, "remap plugin is succesfully initialized");
+  TSDebug(PLUGIN_NAME, "remap plugin is successfully initialized");
   return TS_SUCCESS;                     /* success */
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/header_rewrite/header_rewrite.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/header_rewrite/header_rewrite.cc b/plugins/experimental/header_rewrite/header_rewrite.cc
index 770a968..d1fb49d 100644
--- a/plugins/experimental/header_rewrite/header_rewrite.cc
+++ b/plugins/experimental/header_rewrite/header_rewrite.cc
@@ -272,7 +272,7 @@ TSRemapInit(TSRemapInterface *api_info, char *errbuf, int errbuf_size)
     return TS_ERROR;
   }
 
-  TSDebug(PLUGIN_NAME, "remap plugin is succesfully initialized");
+  TSDebug(PLUGIN_NAME, "remap plugin is successfully initialized");
   return TS_SUCCESS;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/hipes/hipes.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/hipes/hipes.cc b/plugins/experimental/hipes/hipes.cc
index 1bbdbee..fadd594 100644
--- a/plugins/experimental/hipes/hipes.cc
+++ b/plugins/experimental/hipes/hipes.cc
@@ -176,7 +176,7 @@ TSRemapInit(TSREMAP_INTERFACE *api_info, char *errbuf, int errbuf_size)
     return TS_ERROR;
   }
 
-  INKDebug("hipes", "plugin is succesfully initialized");
+  INKDebug("hipes", "plugin is successfully initialized");
   return TS_SUCCESS;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/memcached_remap/memcached_remap.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/memcached_remap/memcached_remap.cc b/plugins/experimental/memcached_remap/memcached_remap.cc
index e4b16d8..1816864 100644
--- a/plugins/experimental/memcached_remap/memcached_remap.cc
+++ b/plugins/experimental/memcached_remap/memcached_remap.cc
@@ -239,6 +239,6 @@ void TSPluginInit(int argc, const char *argv[])
     TSHttpHookAdd(TS_HTTP_READ_REQUEST_HDR_HOOK, cont);
 
     TSDebug(PLUGIN_NAME,
-            "plugin is succesfully initialized [plugin mode]");
+            "plugin is successfully initialized [plugin mode]");
     return;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/experimental/mysql_remap/mysql_remap.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/mysql_remap/mysql_remap.cc b/plugins/experimental/mysql_remap/mysql_remap.cc
index 269ddbe..4e2e2af 100644
--- a/plugins/experimental/mysql_remap/mysql_remap.cc
+++ b/plugins/experimental/mysql_remap/mysql_remap.cc
@@ -243,7 +243,7 @@ TSPluginInit(int argc, const char *argv[]) {
 
   TSContDataSet (cont, (void *)data);
   
-  TSDebug(PLUGIN_NAME, "plugin is succesfully initialized [plugin mode]");
+  TSDebug(PLUGIN_NAME, "plugin is successfully initialized [plugin mode]");
   iniparser_freedict(ini);
   return;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/header_filter/header_filter.cc
----------------------------------------------------------------------
diff --git a/plugins/header_filter/header_filter.cc b/plugins/header_filter/header_filter.cc
index dc7584b..0b04607 100644
--- a/plugins/header_filter/header_filter.cc
+++ b/plugins/header_filter/header_filter.cc
@@ -150,7 +150,7 @@ TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
     return TS_ERROR;
   }
 
-  TSDebug(PLUGIN_NAME, "remap plugin is succesfully initialized");
+  TSDebug(PLUGIN_NAME, "remap plugin is successfully initialized");
   return TS_SUCCESS;                     /* success */
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/regex_remap/regex_remap.cc
----------------------------------------------------------------------
diff --git a/plugins/regex_remap/regex_remap.cc b/plugins/regex_remap/regex_remap.cc
index 2cfea6d..a99b0c3 100644
--- a/plugins/regex_remap/regex_remap.cc
+++ b/plugins/regex_remap/regex_remap.cc
@@ -558,7 +558,7 @@ TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
   }
 
   setup_memory_allocation();
-  TSDebug(PLUGIN_NAME, "plugin is succesfully initialized");
+  TSDebug(PLUGIN_NAME, "plugin is successfully initialized");
   return TS_SUCCESS;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/plugins/stats_over_http/stats_over_http.c
----------------------------------------------------------------------
diff --git a/plugins/stats_over_http/stats_over_http.c b/plugins/stats_over_http/stats_over_http.c
index 6fef6c8..0b7bb8e 100644
--- a/plugins/stats_over_http/stats_over_http.c
+++ b/plugins/stats_over_http/stats_over_http.c
@@ -137,7 +137,7 @@ json_out_stat(TSRecordType rec_type, void *edata, int registered,
   case TS_RECORDDATATYPE_STRING:
     APPEND_STAT(name, "%s", datum->rec_string); break;
   default:
-    TSDebug("istats", "unkown type for %s: %d", name, data_type);
+    TSDebug("istats", "unknown type for %s: %d", name, data_type);
     break;
   }
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/ControlMatcher.cc
----------------------------------------------------------------------
diff --git a/proxy/ControlMatcher.cc b/proxy/ControlMatcher.cc
index 23451c0..5329a7a 100644
--- a/proxy/ControlMatcher.cc
+++ b/proxy/ControlMatcher.cc
@@ -825,8 +825,8 @@ template<class Data, class Result> int ControlMatcher<Data, Result>::BuildTable(
 /****************************************************************
  *    TEMPLATE INSTANTIATIONS GO HERE
  *
- *  We have to explictly instantiate the templates so that
- *   evertything works on with dec ccx, sun CC, and g++
+ *  We have to explicitly instantiate the templates so that
+ *   everything works on with dec ccx, sun CC, and g++
  *
  *  Details on the different comipilers:
  *

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/InkAPITest.cc
----------------------------------------------------------------------
diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index 51e352a..3ac7731 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -1362,7 +1362,7 @@ REGRESSION_TEST(SDK_API_TSContCreate) (RegressionTest * test, int atype, int *ps
   TSMutex mutexp = TSMutexCreate();
   TSCont contp = TSContCreate(cont_handler, mutexp);
 
-  if (TS_SUCCESS == TSMutexLockTry(mutexp)) { // Mutex is grabbed succesfully
+  if (TS_SUCCESS == TSMutexLockTry(mutexp)) { // Mutex is grabbed successfully
     TSContCall(contp, (TSEvent) 0, NULL);
     TSMutexUnlock(mutexp);
   } else {                       //mutex has problems

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/Main.cc
----------------------------------------------------------------------
diff --git a/proxy/Main.cc b/proxy/Main.cc
index 2495a7a..f825c2e 100644
--- a/proxy/Main.cc
+++ b/proxy/Main.cc
@@ -405,7 +405,7 @@ initialize_process_manager()
     ink_strlcpy(management_directory, Layout::get()->sysconfdir, sizeof(management_directory));
     if (access(management_directory, R_OK) == -1) {
       fprintf(stderr,"unable to access() management path '%s': %d, %s\n", management_directory, errno, strerror(errno));
-      fprintf(stderr,"please set management path via command line '-d <managment directory>'\n");
+      fprintf(stderr,"please set management path via command line '-d <management directory>'\n");
       _exit(1);
     }
   }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/hdrs/HTTP.h
----------------------------------------------------------------------
diff --git a/proxy/hdrs/HTTP.h b/proxy/hdrs/HTTP.h
index d97725a..d9aae03 100644
--- a/proxy/hdrs/HTTP.h
+++ b/proxy/hdrs/HTTP.h
@@ -1296,7 +1296,7 @@ struct HTTPCacheAlt
   //  destroyed we decrement the refcount
   //  on that buffer so that it gets destroyed
   // We don't want to use a ref count ptr (Ptr<>)
-  //  since our ownership model requires explict
+  //  since our ownership model requires explicit
   //  destroys and ref count pointers defeat this
   RefCountObj *m_ext_buffer;
 };

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/hdrs/HdrHeap.cc
----------------------------------------------------------------------
diff --git a/proxy/hdrs/HdrHeap.cc b/proxy/hdrs/HdrHeap.cc
index aced42d..86f3029 100644
--- a/proxy/hdrs/HdrHeap.cc
+++ b/proxy/hdrs/HdrHeap.cc
@@ -892,7 +892,7 @@ HdrHeap::unmarshal(int buf_length, int obj_type, HdrHeapObjImpl ** found_obj, Re
   //   by reference into other header heap therefore we need
   //   to the set the refcount ptr for the strings.  We don't
   //   actually increase the refcount here since for the header
-  //   the lifetime is explict but copies will increase
+  //   the lifetime is explicit but copies will increase
   //   the refcount
   if (block_ref) {
     m_ronly_heap[0].m_ref_count_ptr.m_ptr = block_ref;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/http/HttpTransact.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransact.cc b/proxy/http/HttpTransact.cc
index b47a65d..ead53e6 100644
--- a/proxy/http/HttpTransact.cc
+++ b/proxy/http/HttpTransact.cc
@@ -8826,7 +8826,7 @@ void
 HttpTransact::add_new_stat_block(State* s)
 {
   // We keep the block around till the end of transaction
-  //    We don't need explictly deallocate it later since
+  //    We don't need explicitly deallocate it later since
   //    when the transaction is over, the arena will be destroyed
   ink_assert(s->current_stats->next_insert == StatBlockEntries);
   StatBlock *new_block = (StatBlock *) s->arena.alloc(sizeof(StatBlock));

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/http/HttpTunnel.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTunnel.cc b/proxy/http/HttpTunnel.cc
index d468845..73a89ef 100644
--- a/proxy/http/HttpTunnel.cc
+++ b/proxy/http/HttpTunnel.cc
@@ -79,7 +79,7 @@ chunked_reenable(HttpTunnelProducer * p, HttpTunnel * tunnel)
       // Also, make sure the tunnel has not been deallocated on
       //  the call to tunnel->main_handler
       if (r == EVENT_CONT && p->alive && p->chunked_handler.state != ChunkedHandler::CHUNK_FLOW_CONTROL) {
-        // INKqa05737 - since we explictly disabled the vc by setting
+        // INKqa05737 - since we explicitly disabled the vc by setting
         //  nbytes = ndone when going into flow control, we need
         //  set nbytes up again here
         p->read_vio->nbytes = INT64_MAX;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/logging/Log.h
----------------------------------------------------------------------
diff --git a/proxy/logging/Log.h b/proxy/logging/Log.h
index 7e47338..3dd8ce4 100644
--- a/proxy/logging/Log.h
+++ b/proxy/logging/Log.h
@@ -264,7 +264,7 @@
   @verbatim
   int Log::access (LogAccess *entry);
 
-  The return value is Log::OK if all log objects succesfully logged the
+  The return value is Log::OK if all log objects successfully logged the
   entry. Otherwise, it has the following bits set to indicate what happened
 
   ret_val & Log::SKIP      - at least one object filtered the entry

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/78b81341/proxy/logging/LogStandalone.cc
----------------------------------------------------------------------
diff --git a/proxy/logging/LogStandalone.cc b/proxy/logging/LogStandalone.cc
index 0878333..ba0f6d2 100644
--- a/proxy/logging/LogStandalone.cc
+++ b/proxy/logging/LogStandalone.cc
@@ -107,7 +107,7 @@ initialize_process_manager()
     if (access(management_directory, R_OK) == -1) {
       fprintf(stderr,"unable to access() management path '%s': %d, %s\n",
               management_directory, errno, strerror(errno));
-      fprintf(stderr,"please set management path via command line '-d <managment directory>'\n");
+      fprintf(stderr,"please set management path via command line '-d <management directory>'\n");
       _exit(1);
     }
   }