You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by so...@apache.org on 2016/05/06 22:05:41 UTC

[trafficserver] 02/02: TS-4418: Update code with new .clang-format config change

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

sorber pushed a commit to branch master
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit c32379b6ca427598a5046cca5c60fe832a2b5da4
Author: Phil Sorber <so...@apache.org>
AuthorDate: Fri May 6 16:00:03 2016 -0600

    TS-4418: Update code with new .clang-format config change
---
 cmd/traffic_manager/StatType.cc                    |  36 +++-
 iocore/cache/CachePages.cc                         |  11 +-
 iocore/cache/CacheTest.cc                          |  18 +-
 iocore/cache/I_Cache.h                             |   4 +-
 iocore/cache/I_Store.h                             |   9 +-
 iocore/cache/P_CacheDisk.h                         |  18 +-
 iocore/cache/P_CacheHosting.h                      |   8 +-
 iocore/cache/P_CacheInternal.h                     |  10 +-
 iocore/cache/P_CacheVol.h                          |  28 ++-
 iocore/cache/RamCacheCLFUS.cc                      |  14 +-
 iocore/cluster/ClusterConfig.cc                    |   9 +-
 iocore/cluster/ClusterHandler.cc                   |  82 ++++++--
 iocore/cluster/ClusterHandlerBase.cc               |  26 ++-
 iocore/cluster/ClusterLoadMonitor.cc               |  10 +-
 iocore/cluster/ClusterMachine.cc                   |  13 +-
 iocore/cluster/ClusterVConnection.cc               |  32 +++-
 iocore/cluster/P_ClusterCacheInternal.h            |  71 ++++++-
 iocore/cluster/P_ClusterHandler.h                  |  17 +-
 iocore/dns/DNS.cc                                  |  11 +-
 iocore/dns/P_DNSProcessor.h                        |  32 +++-
 iocore/eventsystem/I_IOBuffer.h                    |   7 +-
 iocore/eventsystem/P_IOBuffer.h                    |   4 +-
 iocore/eventsystem/P_UnixEvent.h                   |  10 +-
 iocore/eventsystem/UnixEThread.cc                  |  31 ++-
 iocore/hostdb/MultiCache.cc                        |  13 +-
 iocore/hostdb/P_HostDBProcessor.h                  |  15 +-
 iocore/net/I_NetVConnection.h                      |  10 +-
 iocore/net/NetVCTest.cc                            |  33 +++-
 iocore/net/P_Socks.h                               |  21 ++-
 iocore/net/SSLNetVConnection.cc                    |  25 ++-
 iocore/net/UnixNetAccept.cc                        |  13 +-
 iocore/net/UnixNetVConnection.cc                   |  22 ++-
 iocore/net/UnixUDPNet.cc                           |  24 ++-
 iocore/utils/OneWayTunnel.cc                       |  28 ++-
 lib/atscppapi/src/AsyncHttpFetch.cc                |  10 +-
 lib/atscppapi/src/AsyncTimer.cc                    |   8 +-
 lib/atscppapi/src/InterceptPlugin.cc               |  13 +-
 lib/atscppapi/src/Logger.cc                        |   9 +-
 lib/atscppapi/src/Request.cc                       |   6 +-
 lib/atscppapi/src/Transaction.cc                   |  17 +-
 lib/atscppapi/src/TransformationPlugin.cc          |  12 +-
 lib/records/RecHttp.cc                             |   9 +-
 lib/ts/BaseLogFile.cc                              |  14 +-
 lib/ts/Diags.cc                                    |   7 +-
 lib/ts/ink_cap.cc                                  |   4 +-
 mgmt/Rollback.cc                                   |   9 +-
 .../experimental/ats_pagespeed/ats_base_fetch.cc   |  18 +-
 .../ats_pagespeed/ats_beacon_intercept.cc          |  12 +-
 .../ats_pagespeed/ats_resource_intercept.h         |  10 +-
 .../ats_pagespeed/ats_rewrite_driver_factory.cc    |   3 +-
 .../ats_pagespeed/ats_rewrite_options.h            |   5 +-
 .../ats_pagespeed/ats_server_context.cc            |   3 +-
 plugins/experimental/authproxy/authproxy.cc        |  11 +-
 .../background_fetch/background_fetch.cc           |  13 +-
 plugins/experimental/esi/combo_handler.cc          |  13 +-
 plugins/experimental/esi/esi.cc                    |  27 ++-
 plugins/experimental/esi/lib/EsiProcessor.cc       |  18 +-
 plugins/experimental/esi/lib/Variables.h           |   5 +-
 plugins/experimental/esi/serverIntercept.cc        |  12 +-
 plugins/experimental/hipes/hipes.cc                |  16 +-
 plugins/experimental/inliner/cache-handler.h       |   9 +-
 plugins/experimental/inliner/fetcher.h             |   9 +-
 plugins/experimental/inliner/ts.cc                 |  12 +-
 plugins/experimental/mp4/mp4_meta.h                |  40 +++-
 plugins/experimental/multiplexer/fetcher.h         |   9 +-
 plugins/header_rewrite/resources.h                 |  24 ++-
 plugins/header_rewrite/ruleset.h                   |   7 +-
 plugins/regex_remap/regex_remap.cc                 |  36 +++-
 proxy/CacheControl.h                               |  17 +-
 proxy/ControlMatcher.cc                            |   8 +-
 proxy/ICP.cc                                       |  47 ++++-
 proxy/ICP.h                                        |  19 +-
 proxy/IPAllow.h                                    |   4 +-
 proxy/InkAPI.cc                                    |  18 +-
 proxy/Main.cc                                      |  15 +-
 proxy/ParentSelection.h                            |  16 +-
 proxy/PluginVC.cc                                  |  25 ++-
 proxy/PluginVC.h                                   |  13 +-
 proxy/Prefetch.h                                   |  32 +++-
 proxy/RegressionSM.h                               |  13 +-
 proxy/SocksProxy.cc                                |  10 +-
 proxy/TestProxy.cc                                 |  14 +-
 proxy/Transform.cc                                 |  25 ++-
 proxy/congest/Congestion.cc                        |  11 +-
 proxy/congest/Congestion.h                         |  34 +++-
 proxy/congest/CongestionTest.cc                    |   9 +-
 proxy/hdrs/HTTP.cc                                 |  14 +-
 proxy/hdrs/HdrUtils.h                              |  12 +-
 proxy/http/Http1ClientSession.cc                   |  17 +-
 proxy/http/HttpCacheSM.cc                          |  24 ++-
 proxy/http/HttpConfig.h                            | 201 +++++++++++++++-----
 proxy/http/HttpSM.cc                               |  75 ++++++--
 proxy/http/HttpServerSession.h                     |  20 +-
 proxy/http/HttpTransact.h                          | 209 ++++++++++++++++-----
 proxy/http/HttpTransactCache.h                     |  12 +-
 proxy/http/HttpTunnel.cc                           |  70 ++++++-
 proxy/http/HttpTunnel.h                            |   5 +-
 proxy/http/HttpUpdateTester.cc                     |   6 +-
 proxy/http/remap/RemapPluginInfo.cc                |  12 +-
 proxy/http/remap/UrlMapping.cc                     |  19 +-
 proxy/http/remap/UrlRewrite.cc                     |  12 +-
 proxy/http2/Http2ClientSession.cc                  |   8 +-
 proxy/http2/Http2ConnectionState.h                 |  10 +-
 proxy/http2/Http2Stream.h                          |  26 ++-
 proxy/logging/LogAccessHttp.cc                     |  28 ++-
 proxy/logging/LogBuffer.cc                         |  12 +-
 proxy/logging/LogCollationClientSM.cc              |  21 ++-
 proxy/logging/LogCollationHostSM.cc                |  16 +-
 proxy/logging/LogConfig.cc                         |  16 +-
 proxy/logging/LogField.cc                          |  70 +++++--
 proxy/logging/LogFile.cc                           |  13 +-
 proxy/logging/LogFormat.cc                         |  42 ++++-
 proxy/logging/LogHost.cc                           |  22 ++-
 proxy/logging/LogObject.cc                         |  24 ++-
 proxy/logstats.cc                                  |  14 +-
 proxy/shared/UglyLogStubs.cc                       |  18 +-
 proxy/spdy/SpdyClientSession.h                     |  39 +++-
 117 files changed, 2104 insertions(+), 458 deletions(-)

diff --git a/cmd/traffic_manager/StatType.cc b/cmd/traffic_manager/StatType.cc
index d1505ca..bea1ec0 100644
--- a/cmd/traffic_manager/StatType.cc
+++ b/cmd/traffic_manager/StatType.cc
@@ -398,16 +398,40 @@ StatExprList::count()
  */
 
 StatObject::StatObject()
-  : m_id(1), m_debug(false), m_expr_string(NULL), m_node_dest(NULL), m_cluster_dest(NULL), m_expression(NULL), m_postfix(NULL),
-    m_last_update(-1), m_current_time(-1), m_update_interval(-1), m_stats_max(FLT_MAX), m_stats_min(FLT_MIN), m_has_max(false),
-    m_has_min(false), m_has_delta(false)
+  : m_id(1),
+    m_debug(false),
+    m_expr_string(NULL),
+    m_node_dest(NULL),
+    m_cluster_dest(NULL),
+    m_expression(NULL),
+    m_postfix(NULL),
+    m_last_update(-1),
+    m_current_time(-1),
+    m_update_interval(-1),
+    m_stats_max(FLT_MAX),
+    m_stats_min(FLT_MIN),
+    m_has_max(false),
+    m_has_min(false),
+    m_has_delta(false)
 {
 }
 
 StatObject::StatObject(unsigned identifier)
-  : m_id(identifier), m_debug(false), m_expr_string(NULL), m_node_dest(NULL), m_cluster_dest(NULL), m_expression(NULL),
-    m_postfix(NULL), m_last_update(-1), m_current_time(-1), m_update_interval(-1), m_stats_max(FLT_MAX), m_stats_min(FLT_MIN),
-    m_has_max(false), m_has_min(false), m_has_delta(false)
+  : m_id(identifier),
+    m_debug(false),
+    m_expr_string(NULL),
+    m_node_dest(NULL),
+    m_cluster_dest(NULL),
+    m_expression(NULL),
+    m_postfix(NULL),
+    m_last_update(-1),
+    m_current_time(-1),
+    m_update_interval(-1),
+    m_stats_max(FLT_MAX),
+    m_stats_min(FLT_MIN),
+    m_has_max(false),
+    m_has_min(false),
+    m_has_delta(false)
 {
 }
 
diff --git a/iocore/cache/CachePages.cc b/iocore/cache/CachePages.cc
index a170c6e..9d042b1 100644
--- a/iocore/cache/CachePages.cc
+++ b/iocore/cache/CachePages.cc
@@ -66,8 +66,15 @@ struct ShowCache : public ShowCont {
   int handleCacheScanCallback(int event, Event *e);
 
   ShowCache(Continuation *c, HTTPHdr *h)
-    : ShowCont(c, h), vol_index(0), seg_index(0), scan_flag(scan_type_lookup), cache_vc(0), buffer(0), buffer_reader(0),
-      content_length(0), cvio(0)
+    : ShowCont(c, h),
+      vol_index(0),
+      seg_index(0),
+      scan_flag(scan_type_lookup),
+      cache_vc(0),
+      buffer(0),
+      buffer_reader(0),
+      content_length(0),
+      cvio(0)
   {
     urlstrs_index = 0;
     linecount = 0;
diff --git a/iocore/cache/CacheTest.cc b/iocore/cache/CacheTest.cc
index 19bccde..7673263 100644
--- a/iocore/cache/CacheTest.cc
+++ b/iocore/cache/CacheTest.cc
@@ -30,9 +30,21 @@
 using namespace std;
 
 CacheTestSM::CacheTestSM(RegressionTest *t, const char *name)
-  : RegressionSM(t), cache_test_name(name), timeout(0), cache_action(0), start_time(0), cache_vc(0), cvio(0), buffer(0),
-    buffer_reader(0), nbytes(-1), repeat_count(0), expect_event(EVENT_NONE), expect_initial_event(EVENT_NONE),
-    initial_event(EVENT_NONE), content_salt(0)
+  : RegressionSM(t),
+    cache_test_name(name),
+    timeout(0),
+    cache_action(0),
+    start_time(0),
+    cache_vc(0),
+    cvio(0),
+    buffer(0),
+    buffer_reader(0),
+    nbytes(-1),
+    repeat_count(0),
+    expect_event(EVENT_NONE),
+    expect_initial_event(EVENT_NONE),
+    initial_event(EVENT_NONE),
+    content_salt(0)
 {
   SET_HANDLER(&CacheTestSM::event_handler);
 }
diff --git a/iocore/cache/I_Cache.h b/iocore/cache/I_Cache.h
index eb8bdbd..b1c0cfe 100644
--- a/iocore/cache/I_Cache.h
+++ b/iocore/cache/I_Cache.h
@@ -67,7 +67,9 @@ typedef HTTPInfo CacheHTTPInfo;
 struct CacheProcessor : public Processor {
   CacheProcessor()
     : min_stripe_version(CACHE_DB_MAJOR_VERSION, CACHE_DB_MINOR_VERSION),
-      max_stripe_version(CACHE_DB_MAJOR_VERSION, CACHE_DB_MINOR_VERSION), cb_after_init(0), wait_for_cache(0)
+      max_stripe_version(CACHE_DB_MAJOR_VERSION, CACHE_DB_MINOR_VERSION),
+      cb_after_init(0),
+      wait_for_cache(0)
   {
   }
 
diff --git a/iocore/cache/I_Store.h b/iocore/cache/I_Store.h
index ee45ffc..59968c0 100644
--- a/iocore/cache/I_Store.h
+++ b/iocore/cache/I_Store.h
@@ -155,8 +155,13 @@ public:
   void volume_number_set(int n);
 
   Span()
-    : blocks(0), offset(0), hw_sector_size(DEFAULT_HW_SECTOR_SIZE), alignment(0), forced_volume_num(-1),
-      is_mmapable_internal(false), file_pathname(false)
+    : blocks(0),
+      offset(0),
+      hw_sector_size(DEFAULT_HW_SECTOR_SIZE),
+      alignment(0),
+      forced_volume_num(-1),
+      is_mmapable_internal(false),
+      file_pathname(false)
   {
     disk_id[0] = disk_id[1] = 0;
   }
diff --git a/iocore/cache/P_CacheDisk.h b/iocore/cache/P_CacheDisk.h
index 63a6edb..b391625 100644
--- a/iocore/cache/P_CacheDisk.h
+++ b/iocore/cache/P_CacheDisk.h
@@ -103,8 +103,22 @@ struct CacheDisk : public Continuation {
   ats_scoped_str hash_base_string; ///< Base string for hash seed.
 
   CacheDisk()
-    : Continuation(new_ProxyMutex()), header(NULL), path(NULL), header_len(0), len(0), start(0), skip(0), num_usable_blocks(0),
-      fd(-1), free_space(0), wasted_space(0), disk_vols(NULL), free_blocks(NULL), num_errors(0), cleared(0), read_only_p(false),
+    : Continuation(new_ProxyMutex()),
+      header(NULL),
+      path(NULL),
+      header_len(0),
+      len(0),
+      start(0),
+      skip(0),
+      num_usable_blocks(0),
+      fd(-1),
+      free_space(0),
+      wasted_space(0),
+      disk_vols(NULL),
+      free_blocks(NULL),
+      num_errors(0),
+      cleared(0),
+      read_only_p(false),
       forced_volume_num(-1)
   {
   }
diff --git a/iocore/cache/P_CacheHosting.h b/iocore/cache/P_CacheHosting.h
index 5cb025b..0c4b7fd 100644
--- a/iocore/cache/P_CacheHosting.h
+++ b/iocore/cache/P_CacheHosting.h
@@ -55,7 +55,13 @@ struct CacheHostRecord {
   int num_cachevols;
 
   CacheHostRecord()
-    : type(CACHE_NONE_TYPE), vols(NULL), good_num_vols(0), num_vols(0), num_initialized(0), vol_hash_table(0), cp(NULL),
+    : type(CACHE_NONE_TYPE),
+      vols(NULL),
+      good_num_vols(0),
+      num_vols(0),
+      num_initialized(0),
+      vol_hash_table(0),
+      cp(NULL),
       num_cachevols(0)
   {
   }
diff --git a/iocore/cache/P_CacheInternal.h b/iocore/cache/P_CacheInternal.h
index 22f6b0c..8db829b 100644
--- a/iocore/cache/P_CacheInternal.h
+++ b/iocore/cache/P_CacheInternal.h
@@ -992,8 +992,14 @@ struct Cache {
   Vol *key_to_vol(const CacheKey *key, char const *hostname, int host_len);
 
   Cache()
-    : cache_read_done(0), total_good_nvol(0), total_nvol(0), ready(CACHE_INITIALIZING), cache_size(0), // in store block size
-      hosttable(NULL), total_initialized_vol(0), scheme(CACHE_NONE_TYPE)
+    : cache_read_done(0),
+      total_good_nvol(0),
+      total_nvol(0),
+      ready(CACHE_INITIALIZING),
+      cache_size(0), // in store block size
+      hosttable(NULL),
+      total_initialized_vol(0),
+      scheme(CACHE_NONE_TYPE)
   {
   }
 };
diff --git a/iocore/cache/P_CacheVol.h b/iocore/cache/P_CacheVol.h
index 9009d80..de1a38c 100644
--- a/iocore/cache/P_CacheVol.h
+++ b/iocore/cache/P_CacheVol.h
@@ -246,10 +246,30 @@ struct Vol : public Continuation {
   uint32_t round_to_approx_size(uint32_t l);
 
   Vol()
-    : Continuation(new_ProxyMutex()), path(NULL), fd(-1), dir(0), buckets(0), recover_pos(0), prev_recover_pos(0), scan_pos(0),
-      skip(0), start(0), len(0), data_blocks(0), hit_evacuate_window(0), agg_todo_size(0), agg_buf_pos(0), trigger(0),
-      evacuate_size(0), disk(NULL), last_sync_serial(0), last_write_serial(0), recover_wrapped(false), dir_sync_waiting(0),
-      dir_sync_in_progress(0), writing_end_marker(0)
+    : Continuation(new_ProxyMutex()),
+      path(NULL),
+      fd(-1),
+      dir(0),
+      buckets(0),
+      recover_pos(0),
+      prev_recover_pos(0),
+      scan_pos(0),
+      skip(0),
+      start(0),
+      len(0),
+      data_blocks(0),
+      hit_evacuate_window(0),
+      agg_todo_size(0),
+      agg_buf_pos(0),
+      trigger(0),
+      evacuate_size(0),
+      disk(NULL),
+      last_sync_serial(0),
+      last_write_serial(0),
+      recover_wrapped(false),
+      dir_sync_waiting(0),
+      dir_sync_in_progress(0),
+      writing_end_marker(0)
   {
     open_dir.mutex = mutex;
     agg_buffer = (char *)ats_memalign(ats_pagesize(), AGG_SIZE);
diff --git a/iocore/cache/RamCacheCLFUS.cc b/iocore/cache/RamCacheCLFUS.cc
index f78d7f2..c186214 100644
--- a/iocore/cache/RamCacheCLFUS.cc
+++ b/iocore/cache/RamCacheCLFUS.cc
@@ -102,8 +102,18 @@ struct RamCacheCLFUS : public RamCache {
   void requeue_victims(Que(RamCacheCLFUSEntry, lru_link) & victims);
   void tick(); // move CLOCK on history
   RamCacheCLFUS()
-    : max_bytes(0), bytes(0), objects(0), vol(0), average_value(0), history(0), ibuckets(0), nbuckets(0), bucket(0), seen(0),
-      ncompressed(0), compressed(0)
+    : max_bytes(0),
+      bytes(0),
+      objects(0),
+      vol(0),
+      average_value(0),
+      history(0),
+      ibuckets(0),
+      nbuckets(0),
+      bucket(0),
+      seen(0),
+      ncompressed(0),
+      compressed(0)
   {
   }
 };
diff --git a/iocore/cluster/ClusterConfig.cc b/iocore/cluster/ClusterConfig.cc
index 8819546..499550b 100644
--- a/iocore/cluster/ClusterConfig.cc
+++ b/iocore/cluster/ClusterConfig.cc
@@ -31,8 +31,13 @@
 int cluster_port = DEFAULT_CLUSTER_PORT_NUMBER;
 
 ClusterAccept::ClusterAccept(int *port, int send_bufsize, int recv_bufsize)
-  : Continuation(0), p_cluster_port(port), socket_send_bufsize(send_bufsize), socket_recv_bufsize(recv_bufsize),
-    current_cluster_port(-1), accept_action(0), periodic_event(0)
+  : Continuation(0),
+    p_cluster_port(port),
+    socket_send_bufsize(send_bufsize),
+    socket_recv_bufsize(recv_bufsize),
+    current_cluster_port(-1),
+    accept_action(0),
+    periodic_event(0)
 {
   mutex = new_ProxyMutex();
   SET_HANDLER(&ClusterAccept::ClusterAcceptEvent);
diff --git a/iocore/cluster/ClusterHandler.cc b/iocore/cluster/ClusterHandler.cc
index b33229e..da07b4d 100644
--- a/iocore/cluster/ClusterHandler.cc
+++ b/iocore/cluster/ClusterHandler.cc
@@ -133,22 +133,78 @@ verify_peters_data(char *ap, int l)
 /*************************************************************************/
 
 ClusterHandler::ClusterHandler()
-  : net_vc(0), thread(0), ip(0), port(0), hostname(NULL), machine(NULL), ifd(-1), id(-1), dead(true), downing(false), active(false),
-    on_stolen_thread(false), n_channels(0), channels(NULL), channel_data(NULL), connector(false),
-    cluster_connect_state(ClusterHandler::CLCON_INITIAL), needByteSwap(false), configLookupFails(0), cluster_periodic_event(0),
-    read(this, true), write(this, false), current_time(0), last(0), last_report(0), n_since_last_report(0),
-    last_cluster_op_enable(0), last_trace_dump(0), clm(0), disable_remote_cluster_ops(0), pw_write_descriptors_built(0),
-    pw_freespace_descriptors_built(0), pw_controldata_descriptors_built(0), pw_time_expired(0), started_on_stolen_thread(false),
+  : net_vc(0),
+    thread(0),
+    ip(0),
+    port(0),
+    hostname(NULL),
+    machine(NULL),
+    ifd(-1),
+    id(-1),
+    dead(true),
+    downing(false),
+    active(false),
+    on_stolen_thread(false),
+    n_channels(0),
+    channels(NULL),
+    channel_data(NULL),
+    connector(false),
+    cluster_connect_state(ClusterHandler::CLCON_INITIAL),
+    needByteSwap(false),
+    configLookupFails(0),
+    cluster_periodic_event(0),
+    read(this, true),
+    write(this, false),
+    current_time(0),
+    last(0),
+    last_report(0),
+    n_since_last_report(0),
+    last_cluster_op_enable(0),
+    last_trace_dump(0),
+    clm(0),
+    disable_remote_cluster_ops(0),
+    pw_write_descriptors_built(0),
+    pw_freespace_descriptors_built(0),
+    pw_controldata_descriptors_built(0),
+    pw_time_expired(0),
+    started_on_stolen_thread(false),
     control_message_write(false)
 #ifdef CLUSTER_STATS
     ,
-    _vc_writes(0), _vc_write_bytes(0), _control_write_bytes(0), _dw_missed_lock(0), _dw_not_enabled(0), _dw_wait_remote_fill(0),
-    _dw_no_active_vio(0), _dw_not_enabled_or_no_write(0), _dw_set_data_pending(0), _dw_no_free_space(0), _fw_missed_lock(0),
-    _fw_not_enabled(0), _fw_wait_remote_fill(0), _fw_no_active_vio(0), _fw_not_enabled_or_no_read(0), _process_read_calls(0),
-    _n_read_start(0), _n_read_header(0), _n_read_await_header(0), _n_read_setup_descriptor(0), _n_read_descriptor(0),
-    _n_read_await_descriptor(0), _n_read_setup_data(0), _n_read_data(0), _n_read_await_data(0), _n_read_post_complete(0),
-    _n_read_complete(0), _process_write_calls(0), _n_write_start(0), _n_write_setup(0), _n_write_initiate(0),
-    _n_write_await_completion(0), _n_write_post_complete(0), _n_write_complete(0)
+    _vc_writes(0),
+    _vc_write_bytes(0),
+    _control_write_bytes(0),
+    _dw_missed_lock(0),
+    _dw_not_enabled(0),
+    _dw_wait_remote_fill(0),
+    _dw_no_active_vio(0),
+    _dw_not_enabled_or_no_write(0),
+    _dw_set_data_pending(0),
+    _dw_no_free_space(0),
+    _fw_missed_lock(0),
+    _fw_not_enabled(0),
+    _fw_wait_remote_fill(0),
+    _fw_no_active_vio(0),
+    _fw_not_enabled_or_no_read(0),
+    _process_read_calls(0),
+    _n_read_start(0),
+    _n_read_header(0),
+    _n_read_await_header(0),
+    _n_read_setup_descriptor(0),
+    _n_read_descriptor(0),
+    _n_read_await_descriptor(0),
+    _n_read_setup_data(0),
+    _n_read_data(0),
+    _n_read_await_data(0),
+    _n_read_post_complete(0),
+    _n_read_complete(0),
+    _process_write_calls(0),
+    _n_write_start(0),
+    _n_write_setup(0),
+    _n_write_initiate(0),
+    _n_write_await_completion(0),
+    _n_write_post_complete(0),
+    _n_write_complete(0)
 #endif
 {
 #ifdef MSG_TRACE
diff --git a/iocore/cluster/ClusterHandlerBase.cc b/iocore/cluster/ClusterHandlerBase.cc
index 723b155..a396f7c 100644
--- a/iocore/cluster/ClusterHandlerBase.cc
+++ b/iocore/cluster/ClusterHandlerBase.cc
@@ -209,9 +209,29 @@ OutgoingControl::freeall()
 // ClusterState member functions (Internal Class)
 /*************************************************************************/
 ClusterState::ClusterState(ClusterHandler *c, bool read_chan)
-  : Continuation(0), ch(c), read_channel(read_chan), do_iodone_event(false), n_descriptors(0), sequence_number(0), to_do(0), did(0),
-    n_iov(0), io_complete(1), io_complete_event(0), v(0), bytes_xfered(0), last_ndone(0), total_bytes_xfered(0), iov(NULL),
-    iob_iov(NULL), byte_bank(NULL), n_byte_bank(0), byte_bank_size(0), missed(0), missed_msg(false), read_state_t(READ_START),
+  : Continuation(0),
+    ch(c),
+    read_channel(read_chan),
+    do_iodone_event(false),
+    n_descriptors(0),
+    sequence_number(0),
+    to_do(0),
+    did(0),
+    n_iov(0),
+    io_complete(1),
+    io_complete_event(0),
+    v(0),
+    bytes_xfered(0),
+    last_ndone(0),
+    total_bytes_xfered(0),
+    iov(NULL),
+    iob_iov(NULL),
+    byte_bank(NULL),
+    n_byte_bank(0),
+    byte_bank_size(0),
+    missed(0),
+    missed_msg(false),
+    read_state_t(READ_START),
     write_state_t(WRITE_START)
 {
   mutex = new_ProxyMutex();
diff --git a/iocore/cluster/ClusterLoadMonitor.cc b/iocore/cluster/ClusterLoadMonitor.cc
index 4c0020d..42af4cf 100644
--- a/iocore/cluster/ClusterLoadMonitor.cc
+++ b/iocore/cluster/ClusterLoadMonitor.cc
@@ -39,8 +39,14 @@ int ClusterLoadMonitor::cf_cluster_load_clear_duration;
 int ClusterLoadMonitor::cf_cluster_load_exceed_duration;
 
 ClusterLoadMonitor::ClusterLoadMonitor(ClusterHandler *ch)
-  : Continuation(0), ch(ch), ping_history_buf_head(0), periodic_action(0), cluster_overloaded(0), cancel_periodic(0),
-    cluster_load_msg_sequence_number(0), cluster_load_msg_start_sequence_number(0)
+  : Continuation(0),
+    ch(ch),
+    ping_history_buf_head(0),
+    periodic_action(0),
+    cluster_overloaded(0),
+    cancel_periodic(0),
+    cluster_load_msg_sequence_number(0),
+    cluster_load_msg_start_sequence_number(0)
 {
   mutex = this->ch->mutex;
   SET_HANDLER(&ClusterLoadMonitor::cluster_load_periodic);
diff --git a/iocore/cluster/ClusterMachine.cc b/iocore/cluster/ClusterMachine.cc
index 3453320..3dd80e8 100644
--- a/iocore/cluster/ClusterMachine.cc
+++ b/iocore/cluster/ClusterMachine.cc
@@ -66,8 +66,17 @@ create_this_cluster_machine()
 }
 
 ClusterMachine::ClusterMachine(char *ahostname, unsigned int aip, int aport)
-  : dead(false), hostname(ahostname), ip(aip), cluster_port(aport), num_connections(0), now_connections(0), free_connections(0),
-    rr_count(0), msg_proto_major(0), msg_proto_minor(0), clusterHandlers(0)
+  : dead(false),
+    hostname(ahostname),
+    ip(aip),
+    cluster_port(aport),
+    num_connections(0),
+    now_connections(0),
+    free_connections(0),
+    rr_count(0),
+    msg_proto_major(0),
+    msg_proto_minor(0),
+    clusterHandlers(0)
 {
   EThread *thread = this_ethread();
   ProxyMutex *mutex = thread->mutex;
diff --git a/iocore/cluster/ClusterVConnection.cc b/iocore/cluster/ClusterVConnection.cc
index 8e8b09a..1fa0f64 100644
--- a/iocore/cluster/ClusterVConnection.cc
+++ b/iocore/cluster/ClusterVConnection.cc
@@ -187,11 +187,33 @@ ClusterVConnectionBase::reenable_re(VIO *vio)
 }
 
 ClusterVConnection::ClusterVConnection(int is_new_connect_read)
-  : ch(NULL), new_connect_read(is_new_connect_read), remote_free(0), last_local_free(0), channel(0), close_disabled(0),
-    remote_closed(0), remote_close_disabled(1), remote_lerrno(0), in_vcs(0), type(0), start_time(0), last_activity_time(0),
-    n_set_data_msgs(0), n_recv_set_data_msgs(0), pending_remote_fill(0), remote_ram_cache_hit(0), have_all_data(0),
-    initial_data_bytes(0), current_cont(0), iov_map(CLUSTER_IOV_NOT_OPEN), write_list_tail(0), write_list_bytes(0),
-    write_bytes_in_transit(0), alternate(), time_pin(0), disk_io_priority(0)
+  : ch(NULL),
+    new_connect_read(is_new_connect_read),
+    remote_free(0),
+    last_local_free(0),
+    channel(0),
+    close_disabled(0),
+    remote_closed(0),
+    remote_close_disabled(1),
+    remote_lerrno(0),
+    in_vcs(0),
+    type(0),
+    start_time(0),
+    last_activity_time(0),
+    n_set_data_msgs(0),
+    n_recv_set_data_msgs(0),
+    pending_remote_fill(0),
+    remote_ram_cache_hit(0),
+    have_all_data(0),
+    initial_data_bytes(0),
+    current_cont(0),
+    iov_map(CLUSTER_IOV_NOT_OPEN),
+    write_list_tail(0),
+    write_list_bytes(0),
+    write_bytes_in_transit(0),
+    alternate(),
+    time_pin(0),
+    disk_io_priority(0)
 {
 #ifdef DEBUG
   read.vio.buffer.name = "ClusterVConnection.read";
diff --git a/iocore/cluster/P_ClusterCacheInternal.h b/iocore/cluster/P_ClusterCacheInternal.h
index 62b665a..b0b4d15 100644
--- a/iocore/cluster/P_ClusterCacheInternal.h
+++ b/iocore/cluster/P_ClusterCacheInternal.h
@@ -276,14 +276,51 @@ struct CacheContinuation : public Continuation {
   }
 
   CacheContinuation()
-    : Continuation(NULL), magicno(MagicNo), callback_data(0), callback_data_2(0), timeout(0), target_machine(0), probe_depth(0),
-      start_time(0), cache_read(false), result(0), result_error(0), seq_number(0), cfl_flags(0), frag_type(CACHE_FRAG_TYPE_NONE),
-      nbytes(0), target_ip(0), request_opcode(0), request_purge(false), local_lookup_only(0), no_reply_message(0),
-      request_timeout(0), expect_cache_callback(true), use_deferred_callback(0), pin_in_cache(0), rw_buf_msg_len(0),
-      read_cluster_vc(0), write_cluster_vc(0), cluster_vc_channel(0), caller_buf_freebytes(0), readahead_vio(0),
-      readahead_reader(0), have_all_data(false), cache_vc_info(), tunnel(0), tunnel_cont(0), tunnel_closed(0),
-      lookup_open_write_vc_event(0), ic_arena(), ic_request(), ic_response(), ic_params(0), ic_old_info(), ic_new_info(),
-      ic_hostname_len(0), cache_op_ClusterFunction(0)
+    : Continuation(NULL),
+      magicno(MagicNo),
+      callback_data(0),
+      callback_data_2(0),
+      timeout(0),
+      target_machine(0),
+      probe_depth(0),
+      start_time(0),
+      cache_read(false),
+      result(0),
+      result_error(0),
+      seq_number(0),
+      cfl_flags(0),
+      frag_type(CACHE_FRAG_TYPE_NONE),
+      nbytes(0),
+      target_ip(0),
+      request_opcode(0),
+      request_purge(false),
+      local_lookup_only(0),
+      no_reply_message(0),
+      request_timeout(0),
+      expect_cache_callback(true),
+      use_deferred_callback(0),
+      pin_in_cache(0),
+      rw_buf_msg_len(0),
+      read_cluster_vc(0),
+      write_cluster_vc(0),
+      cluster_vc_channel(0),
+      caller_buf_freebytes(0),
+      readahead_vio(0),
+      readahead_reader(0),
+      have_all_data(false),
+      cache_vc_info(),
+      tunnel(0),
+      tunnel_cont(0),
+      tunnel_closed(0),
+      lookup_open_write_vc_event(0),
+      ic_arena(),
+      ic_request(),
+      ic_response(),
+      ic_params(0),
+      ic_old_info(),
+      ic_new_info(),
+      ic_hostname_len(0),
+      cache_op_ClusterFunction(0)
   {
     token.clear();
     SET_HANDLER((CacheContHandler)&CacheContinuation::remoteOpEvent);
@@ -419,7 +456,14 @@ struct CacheOpMsg_long : public ClusterMessageHeader {
     CACHE_OP_LONG_MESSAGE_VERSION = MAX_VERSION,
   };
   CacheOpMsg_long(uint16_t vers = CACHE_OP_LONG_MESSAGE_VERSION)
-    : ClusterMessageHeader(vers), opcode(0), frag_type(0), cfl_flags(0), seq_number(0), nbytes(0), data(0), channel(0),
+    : ClusterMessageHeader(vers),
+      opcode(0),
+      frag_type(0),
+      cfl_flags(0),
+      seq_number(0),
+      nbytes(0),
+      data(0),
+      channel(0),
       buffer_size(0)
   {
     moi.u32 = 0;
@@ -480,7 +524,14 @@ struct CacheOpMsg_short : public ClusterMessageHeader {
     CACHE_OP_SHORT_MESSAGE_VERSION = MAX_VERSION,
   };
   CacheOpMsg_short(uint16_t vers = CACHE_OP_SHORT_MESSAGE_VERSION)
-    : ClusterMessageHeader(vers), opcode(0), frag_type(0), cfl_flags(0), seq_number(0), nbytes(0), data(0), channel(0),
+    : ClusterMessageHeader(vers),
+      opcode(0),
+      frag_type(0),
+      cfl_flags(0),
+      seq_number(0),
+      nbytes(0),
+      data(0),
+      channel(0),
       buffer_size(0)
   {
     moi.u32 = 0;
diff --git a/iocore/cluster/P_ClusterHandler.h b/iocore/cluster/P_ClusterHandler.h
index c713124..edf2d49 100644
--- a/iocore/cluster/P_ClusterHandler.h
+++ b/iocore/cluster/P_ClusterHandler.h
@@ -315,9 +315,20 @@ struct ClusterMsg {
     return cksum;
   }
   ClusterMsg()
-    : descriptor(NULL), iob_descriptor_block(NULL), count(0), control_bytes(0), descriptor_cksum(0), control_bytes_cksum(0),
-      unused(0), state(0), control_data_offset(0), did_small_control_set_data(0), did_large_control_set_data(0),
-      did_small_control_msgs(0), did_large_control_msgs(0), did_freespace_msgs(0)
+    : descriptor(NULL),
+      iob_descriptor_block(NULL),
+      count(0),
+      control_bytes(0),
+      descriptor_cksum(0),
+      control_bytes_cksum(0),
+      unused(0),
+      state(0),
+      control_data_offset(0),
+      did_small_control_set_data(0),
+      did_large_control_set_data(0),
+      did_small_control_msgs(0),
+      did_large_control_msgs(0),
+      did_freespace_msgs(0)
   {
   }
 };
diff --git a/iocore/dns/DNS.cc b/iocore/dns/DNS.cc
index f024801..fbd0416 100644
--- a/iocore/dns/DNS.cc
+++ b/iocore/dns/DNS.cc
@@ -1685,8 +1685,15 @@ struct DNSRegressionContinuation : public Continuation {
   }
 
   DNSRegressionContinuation(int ahosts, int atofind, const char **ahostnames, RegressionTest *t, int atype, int *astatus)
-    : Continuation(new_ProxyMutex()), hosts(ahosts), hostnames(ahostnames), type(atype), status(astatus), found(0), tofind(atofind),
-      i(0), test(t)
+    : Continuation(new_ProxyMutex()),
+      hosts(ahosts),
+      hostnames(ahostnames),
+      type(atype),
+      status(astatus),
+      found(0),
+      tofind(atofind),
+      i(0),
+      test(t)
   {
     SET_HANDLER((DNSRegContHandler)&DNSRegressionContinuation::mainEvent);
   }
diff --git a/iocore/dns/P_DNSProcessor.h b/iocore/dns/P_DNSProcessor.h
index a11b3cc..2c0f60d 100644
--- a/iocore/dns/P_DNSProcessor.h
+++ b/iocore/dns/P_DNSProcessor.h
@@ -165,9 +165,22 @@ struct DNSEntry : public Continuation {
   void init(const char *x, int len, int qtype_arg, Continuation *acont, DNSProcessor::Options const &opt);
 
   DNSEntry()
-    : Continuation(NULL), qtype(0), host_res_style(HOST_RES_NONE), retries(DEFAULT_DNS_RETRIES), which_ns(NO_NAMESERVER_SELECTED),
-      submit_time(0), send_time(0), qname_len(0), orig_qname_len(0), domains(0), timeout(0), result_ent(0), dnsH(0),
-      written_flag(false), once_written_flag(false), last(false)
+    : Continuation(NULL),
+      qtype(0),
+      host_res_style(HOST_RES_NONE),
+      retries(DEFAULT_DNS_RETRIES),
+      which_ns(NO_NAMESERVER_SELECTED),
+      submit_time(0),
+      send_time(0),
+      qname_len(0),
+      orig_qname_len(0),
+      domains(0),
+      timeout(0),
+      result_ent(0),
+      dnsH(0),
+      written_flag(false),
+      once_written_flag(false),
+      last(false)
   {
     for (int i = 0; i < MAX_DNS_RETRIES; i++)
       id[i] = -1;
@@ -313,8 +326,17 @@ struct DNSServer {
 
 TS_INLINE
 DNSHandler::DNSHandler()
-  : Continuation(NULL), n_con(0), in_flight(0), name_server(0), in_write_dns(0), hostent_cache(0), last_primary_retry(0),
-    last_primary_reopen(0), m_res(0), txn_lookup_timeout(0), generator((uint32_t)((uintptr_t)time(NULL) ^ (uintptr_t)this))
+  : Continuation(NULL),
+    n_con(0),
+    in_flight(0),
+    name_server(0),
+    in_write_dns(0),
+    hostent_cache(0),
+    last_primary_retry(0),
+    last_primary_reopen(0),
+    m_res(0),
+    txn_lookup_timeout(0),
+    generator((uint32_t)((uintptr_t)time(NULL) ^ (uintptr_t)this))
 {
   ats_ip_invalidate(&ip);
   for (int i = 0; i < MAX_NAMED; i++) {
diff --git a/iocore/eventsystem/I_IOBuffer.h b/iocore/eventsystem/I_IOBuffer.h
index 2970759..5931f90 100644
--- a/iocore/eventsystem/I_IOBuffer.h
+++ b/iocore/eventsystem/I_IOBuffer.h
@@ -259,7 +259,9 @@ public:
 
   */
   IOBufferData()
-    : _size_index(BUFFER_SIZE_NOT_ALLOCATED), _mem_type(NO_ALLOC), _data(NULL)
+    : _size_index(BUFFER_SIZE_NOT_ALLOCATED),
+      _mem_type(NO_ALLOC),
+      _data(NULL)
 #ifdef TRACK_BUFFER_USER
       ,
       _location(NULL)
@@ -1215,7 +1217,8 @@ struct MIOBufferAccessor {
 #ifdef DEBUG
       name(NULL),
 #endif
-      mbuf(NULL), entry(NULL)
+      mbuf(NULL),
+      entry(NULL)
   {
   }
 
diff --git a/iocore/eventsystem/P_IOBuffer.h b/iocore/eventsystem/P_IOBuffer.h
index 3ef5a13..1298b89 100644
--- a/iocore/eventsystem/P_IOBuffer.h
+++ b/iocore/eventsystem/P_IOBuffer.h
@@ -358,7 +358,9 @@ new_IOBufferBlock_internal(
 
 TS_INLINE
 IOBufferBlock::IOBufferBlock()
-  : _start(0), _end(0), _buf_end(0)
+  : _start(0),
+    _end(0),
+    _buf_end(0)
 #ifdef TRACK_BUFFER_USER
     ,
     _location(0)
diff --git a/iocore/eventsystem/P_UnixEvent.h b/iocore/eventsystem/P_UnixEvent.h
index a224443..4b2f8b1 100644
--- a/iocore/eventsystem/P_UnixEvent.h
+++ b/iocore/eventsystem/P_UnixEvent.h
@@ -44,8 +44,14 @@ Event::free()
 
 TS_INLINE
 Event::Event()
-  : ethread(0), in_the_prot_queue(false), in_the_priority_queue(false), immediate(false), globally_allocated(true), in_heap(false),
-    timeout_at(0), period(0)
+  : ethread(0),
+    in_the_prot_queue(false),
+    in_the_priority_queue(false),
+    immediate(false),
+    globally_allocated(true),
+    in_heap(false),
+    timeout_at(0),
+    period(0)
 {
 }
 
diff --git a/iocore/eventsystem/UnixEThread.cc b/iocore/eventsystem/UnixEThread.cc
index 4973b51..e395787 100644
--- a/iocore/eventsystem/UnixEThread.cc
+++ b/iocore/eventsystem/UnixEThread.cc
@@ -42,15 +42,27 @@ struct AIOCallback;
 bool shutdown_event_system = false;
 
 EThread::EThread()
-  : generator((uint64_t)Thread::get_hrtime_updated() ^ (uint64_t)(uintptr_t)this), ethreads_to_be_signalled(NULL),
-    n_ethreads_to_be_signalled(0), main_accept_index(-1), id(NO_ETHREAD_ID), event_types(0), signal_hook(0), tt(REGULAR)
+  : generator((uint64_t)Thread::get_hrtime_updated() ^ (uint64_t)(uintptr_t)this),
+    ethreads_to_be_signalled(NULL),
+    n_ethreads_to_be_signalled(0),
+    main_accept_index(-1),
+    id(NO_ETHREAD_ID),
+    event_types(0),
+    signal_hook(0),
+    tt(REGULAR)
 {
   memset(thread_private, 0, PER_THREAD_DATA);
 }
 
 EThread::EThread(ThreadType att, int anid)
-  : generator((uint64_t)Thread::get_hrtime_updated() ^ (uint64_t)(uintptr_t)this), ethreads_to_be_signalled(NULL),
-    n_ethreads_to_be_signalled(0), main_accept_index(-1), id(anid), event_types(0), signal_hook(0), tt(att),
+  : generator((uint64_t)Thread::get_hrtime_updated() ^ (uint64_t)(uintptr_t)this),
+    ethreads_to_be_signalled(NULL),
+    n_ethreads_to_be_signalled(0),
+    main_accept_index(-1),
+    id(anid),
+    event_types(0),
+    signal_hook(0),
+    tt(att),
     server_session_pool(NULL)
 {
   ethreads_to_be_signalled = (EThread **)ats_malloc(MAX_EVENT_THREADS * sizeof(EThread *));
@@ -82,8 +94,15 @@ EThread::EThread(ThreadType att, int anid)
 }
 
 EThread::EThread(ThreadType att, Event *e)
-  : generator((uint32_t)((uintptr_t)time(NULL) ^ (uintptr_t)this)), ethreads_to_be_signalled(NULL), n_ethreads_to_be_signalled(0),
-    main_accept_index(-1), id(NO_ETHREAD_ID), event_types(0), signal_hook(0), tt(att), oneevent(e)
+  : generator((uint32_t)((uintptr_t)time(NULL) ^ (uintptr_t)this)),
+    ethreads_to_be_signalled(NULL),
+    n_ethreads_to_be_signalled(0),
+    main_accept_index(-1),
+    id(NO_ETHREAD_ID),
+    event_types(0),
+    signal_hook(0),
+    tt(att),
+    oneevent(e)
 {
   ink_assert(att == DEDICATED);
   memset(thread_private, 0, PER_THREAD_DATA);
diff --git a/iocore/hostdb/MultiCache.cc b/iocore/hostdb/MultiCache.cc
index e2ae6ee..2e6951a 100644
--- a/iocore/hostdb/MultiCache.cc
+++ b/iocore/hostdb/MultiCache.cc
@@ -62,8 +62,17 @@ store_verify(Store *store)
 }
 
 MultiCacheHeader::MultiCacheHeader()
-  : magic(MULTI_CACHE_MAGIC_NUMBER), levels(0), tag_bits(0), max_hits(0), elementsize(0), buckets(0), totalelements(0),
-    totalsize(0), nominal_elements(0), heap_size(0), heap_halfspace(0)
+  : magic(MULTI_CACHE_MAGIC_NUMBER),
+    levels(0),
+    tag_bits(0),
+    max_hits(0),
+    elementsize(0),
+    buckets(0),
+    totalelements(0),
+    totalsize(0),
+    nominal_elements(0),
+    heap_size(0),
+    heap_halfspace(0)
 {
   memset(level_offset, 0, sizeof(level_offset));
   memset(bucketsize, 0, sizeof(bucketsize));
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index f682fee..3a4ee44 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -541,9 +541,18 @@ struct HostDBContinuation : public Continuation {
   int make_put_message(HostDBInfo *r, Continuation *c, char *buf, int len);
 
   HostDBContinuation()
-    : Continuation(NULL), ttl(0), host_res_style(DEFAULT_OPTIONS.host_res_style), dns_lookup_timeout(DEFAULT_OPTIONS.timeout),
-      timeout(0), from(0), from_cont(0), probe_depth(0), current_iterate_pos(0), missing(false),
-      force_dns(DEFAULT_OPTIONS.force_dns), round_robin(false)
+    : Continuation(NULL),
+      ttl(0),
+      host_res_style(DEFAULT_OPTIONS.host_res_style),
+      dns_lookup_timeout(DEFAULT_OPTIONS.timeout),
+      timeout(0),
+      from(0),
+      from_cont(0),
+      probe_depth(0),
+      current_iterate_pos(0),
+      missing(false),
+      force_dns(DEFAULT_OPTIONS.force_dns),
+      round_robin(false)
   {
     ink_zero(md5_host_name_store);
     ink_zero(md5.hash);
diff --git a/iocore/net/I_NetVConnection.h b/iocore/net/I_NetVConnection.h
index 4143357..e7d147d 100644
--- a/iocore/net/I_NetVConnection.h
+++ b/iocore/net/I_NetVConnection.h
@@ -584,8 +584,14 @@ protected:
 };
 
 inline NetVConnection::NetVConnection()
-  : VConnection(NULL), attributes(0), thread(NULL), got_local_addr(0), got_remote_addr(0), is_internal_request(false),
-    is_transparent(false), write_buffer_empty_event(0)
+  : VConnection(NULL),
+    attributes(0),
+    thread(NULL),
+    got_local_addr(0),
+    got_remote_addr(0),
+    is_internal_request(false),
+    is_transparent(false),
+    write_buffer_empty_event(0)
 {
   ink_zero(local_addr);
   ink_zero(remote_addr);
diff --git a/iocore/net/NetVCTest.cc b/iocore/net/NetVCTest.cc
index 76bb196..f195e56 100644
--- a/iocore/net/NetVCTest.cc
+++ b/iocore/net/NetVCTest.cc
@@ -81,11 +81,34 @@ NVC_test_def netvc_tests_def[] = {
 const unsigned num_netvc_tests = countof(netvc_tests_def);
 
 NetVCTest::NetVCTest()
-  : Continuation(NULL), test_cont_type(NET_VC_TEST_ACTIVE), test_vc(NULL), regress(NULL), driver(NULL), read_vio(NULL),
-    write_vio(NULL), read_buffer(NULL), write_buffer(NULL), reader_for_rbuf(NULL), reader_for_wbuf(NULL), write_bytes_to_add_per(0),
-    timeout(0), actual_bytes_read(0), actual_bytes_sent(0), write_done(false), read_done(false), read_seed(0), write_seed(0),
-    bytes_to_send(0), bytes_to_read(0), nbytes_read(0), nbytes_write(0), expected_read_term(0), expected_write_term(0),
-    test_name(NULL), module_name(NULL), debug_tag(NULL)
+  : Continuation(NULL),
+    test_cont_type(NET_VC_TEST_ACTIVE),
+    test_vc(NULL),
+    regress(NULL),
+    driver(NULL),
+    read_vio(NULL),
+    write_vio(NULL),
+    read_buffer(NULL),
+    write_buffer(NULL),
+    reader_for_rbuf(NULL),
+    reader_for_wbuf(NULL),
+    write_bytes_to_add_per(0),
+    timeout(0),
+    actual_bytes_read(0),
+    actual_bytes_sent(0),
+    write_done(false),
+    read_done(false),
+    read_seed(0),
+    write_seed(0),
+    bytes_to_send(0),
+    bytes_to_read(0),
+    nbytes_read(0),
+    nbytes_write(0),
+    expected_read_term(0),
+    expected_write_term(0),
+    test_name(NULL),
+    module_name(NULL),
+    debug_tag(NULL)
 {
 }
 
diff --git a/iocore/net/P_Socks.h b/iocore/net/P_Socks.h
index aa9cacf..7cf5e24 100644
--- a/iocore/net/P_Socks.h
+++ b/iocore/net/P_Socks.h
@@ -64,8 +64,16 @@ struct socks_conf_struct {
 #endif
 
   socks_conf_struct()
-    : socks_needed(0), server_connect_timeout(0), socks_timeout(100), default_version(5), user_name_n_passwd(NULL),
-      user_name_n_passwd_len(0), per_server_connection_attempts(1), connection_attempts(0), accept_enabled(0), accept_port(0),
+    : socks_needed(0),
+      server_connect_timeout(0),
+      socks_timeout(100),
+      default_version(5),
+      user_name_n_passwd(NULL),
+      user_name_n_passwd_len(0),
+      per_server_connection_attempts(1),
+      connection_attempts(0),
+      accept_enabled(0),
+      accept_port(0),
       http_port(1080)
   {
 #if !defined(SOCKS_WITH_TS)
@@ -136,7 +144,14 @@ struct SocksEntry : public Continuation {
   void free();
 
   SocksEntry()
-    : Continuation(NULL), netVConnection(0), nattempts(0), lerrno(0), timeout(0), version(5), write_done(false), auth_handler(NULL),
+    : Continuation(NULL),
+      netVConnection(0),
+      nattempts(0),
+      lerrno(0),
+      timeout(0),
+      version(5),
+      write_done(false),
+      auth_handler(NULL),
       socks_cmd(NORMAL_SOCKS)
   {
     memset(&target_addr, 0, sizeof(target_addr));
diff --git a/iocore/net/SSLNetVConnection.cc b/iocore/net/SSLNetVConnection.cc
index 3f688bf..5a96db4 100644
--- a/iocore/net/SSLNetVConnection.cc
+++ b/iocore/net/SSLNetVConnection.cc
@@ -826,11 +826,26 @@ SSLNetVConnection::load_buffer_and_write(int64_t towrite, int64_t &wattempted, i
 }
 
 SSLNetVConnection::SSLNetVConnection()
-  : ssl(NULL), sslHandshakeBeginTime(0), sslLastWriteTime(0), sslTotalBytesSent(0), hookOpRequested(TS_SSL_HOOK_OP_DEFAULT),
-    sslHandShakeComplete(false), sslClientConnection(false), sslClientRenegotiationAbort(false), sslSessionCacheHit(false),
-    handShakeBuffer(NULL), handShakeHolder(NULL), handShakeReader(NULL), handShakeBioStored(0),
-    sslPreAcceptHookState(SSL_HOOKS_INIT), sslHandshakeHookState(HANDSHAKE_HOOKS_PRE), npnSet(NULL), npnEndpoint(NULL),
-    sessionAcceptPtr(NULL), eosRcvd(false), sslTrace(false)
+  : ssl(NULL),
+    sslHandshakeBeginTime(0),
+    sslLastWriteTime(0),
+    sslTotalBytesSent(0),
+    hookOpRequested(TS_SSL_HOOK_OP_DEFAULT),
+    sslHandShakeComplete(false),
+    sslClientConnection(false),
+    sslClientRenegotiationAbort(false),
+    sslSessionCacheHit(false),
+    handShakeBuffer(NULL),
+    handShakeHolder(NULL),
+    handShakeReader(NULL),
+    handShakeBioStored(0),
+    sslPreAcceptHookState(SSL_HOOKS_INIT),
+    sslHandshakeHookState(HANDSHAKE_HOOKS_PRE),
+    npnSet(NULL),
+    npnEndpoint(NULL),
+    sessionAcceptPtr(NULL),
+    eosRcvd(false),
+    sslTrace(false)
 {
 }
 
diff --git a/iocore/net/UnixNetAccept.cc b/iocore/net/UnixNetAccept.cc
index 798822f..0510515 100644
--- a/iocore/net/UnixNetAccept.cc
+++ b/iocore/net/UnixNetAccept.cc
@@ -498,8 +498,17 @@ NetAccept::acceptLoopEvent(int event, Event *e)
 //
 
 NetAccept::NetAccept()
-  : Continuation(NULL), period(0), ifd(NO_FD), callback_on_open(false), backdoor(false), recv_bufsize(0), send_bufsize(0),
-    sockopt_flags(0), packet_mark(0), packet_tos(0), etype(0)
+  : Continuation(NULL),
+    period(0),
+    ifd(NO_FD),
+    callback_on_open(false),
+    backdoor(false),
+    recv_bufsize(0),
+    send_bufsize(0),
+    sockopt_flags(0),
+    packet_mark(0),
+    packet_tos(0),
+    etype(0)
 {
 }
 
diff --git a/iocore/net/UnixNetVConnection.cc b/iocore/net/UnixNetVConnection.cc
index 633d9fe..59b30bd 100644
--- a/iocore/net/UnixNetVConnection.cc
+++ b/iocore/net/UnixNetVConnection.cc
@@ -885,14 +885,26 @@ UnixNetVConnection::reenable_re(VIO *vio)
 }
 
 UnixNetVConnection::UnixNetVConnection()
-  : closed(0), inactivity_timeout_in(0), active_timeout_in(0),
+  : closed(0),
+    inactivity_timeout_in(0),
+    active_timeout_in(0),
 #ifdef INACTIVITY_TIMEOUT
-    inactivity_timeout(NULL), active_timeout(NULL),
+    inactivity_timeout(NULL),
+    active_timeout(NULL),
 #else
-    next_inactivity_timeout_at(0), next_activity_timeout_at(0),
+    next_inactivity_timeout_at(0),
+    next_activity_timeout_at(0),
 #endif
-    nh(NULL), id(0), flags(0), recursion(0), submit_time(0), oob_ptr(0), from_accept_thread(false), origin_trace(false),
-    origin_trace_addr(NULL), origin_trace_port(0)
+    nh(NULL),
+    id(0),
+    flags(0),
+    recursion(0),
+    submit_time(0),
+    oob_ptr(0),
+    from_accept_thread(false),
+    origin_trace(false),
+    origin_trace_addr(NULL),
+    origin_trace_port(0)
 {
   memset(&local_addr, 0, sizeof local_addr);
   memset(&server_addr, 0, sizeof server_addr);
diff --git a/iocore/net/UnixUDPNet.cc b/iocore/net/UnixUDPNet.cc
index 856c514..a17d46c 100644
--- a/iocore/net/UnixUDPNet.cc
+++ b/iocore/net/UnixUDPNet.cc
@@ -217,8 +217,16 @@ ClassAllocator<UDPReadContinuation> udpReadContAllocator("udpReadContAllocator")
 #define UNINITIALIZED_EVENT_PTR (Event *)0xdeadbeef
 
 UDPReadContinuation::UDPReadContinuation(Event *completionToken)
-  : Continuation(NULL), event(completionToken), readbuf(NULL), readlen(0), fromaddrlen(0), fd(-1), ifd(-1), period(0),
-    elapsed_time(0), timeout_interval(0)
+  : Continuation(NULL),
+    event(completionToken),
+    readbuf(NULL),
+    readlen(0),
+    fromaddrlen(0),
+    fd(-1),
+    ifd(-1),
+    period(0),
+    elapsed_time(0),
+    timeout_interval(0)
 {
   if (completionToken->continuation)
     this->mutex = completionToken->continuation->mutex;
@@ -227,8 +235,16 @@ UDPReadContinuation::UDPReadContinuation(Event *completionToken)
 }
 
 UDPReadContinuation::UDPReadContinuation()
-  : Continuation(NULL), event(UNINITIALIZED_EVENT_PTR), readbuf(NULL), readlen(0), fromaddrlen(0), fd(-1), ifd(-1), period(0),
-    elapsed_time(0), timeout_interval(0)
+  : Continuation(NULL),
+    event(UNINITIALIZED_EVENT_PTR),
+    readbuf(NULL),
+    readlen(0),
+    fromaddrlen(0),
+    fd(-1),
+    ifd(-1),
+    period(0),
+    elapsed_time(0),
+    timeout_interval(0)
 {
 }
 
diff --git a/iocore/utils/OneWayTunnel.cc b/iocore/utils/OneWayTunnel.cc
index cd642bb..d286a57 100644
--- a/iocore/utils/OneWayTunnel.cc
+++ b/iocore/utils/OneWayTunnel.cc
@@ -63,8 +63,19 @@ transfer_data(MIOBufferAccessor &in_buf, MIOBufferAccessor &out_buf)
 }
 
 OneWayTunnel::OneWayTunnel()
-  : Continuation(0), vioSource(0), vioTarget(0), cont(0), manipulate_fn(0), n_connections(0), lerrno(0), single_buffer(0),
-    close_source(0), close_target(0), tunnel_till_done(0), tunnel_peer(0), free_vcs(true)
+  : Continuation(0),
+    vioSource(0),
+    vioTarget(0),
+    cont(0),
+    manipulate_fn(0),
+    n_connections(0),
+    lerrno(0),
+    single_buffer(0),
+    close_source(0),
+    close_target(0),
+    tunnel_till_done(0),
+    tunnel_peer(0),
+    free_vcs(true)
 {
 }
 
@@ -96,9 +107,16 @@ OneWayTunnel::~OneWayTunnel()
 }
 
 OneWayTunnel::OneWayTunnel(Continuation *aCont, Transform_fn aManipulate_fn, bool aclose_source, bool aclose_target)
-  : Continuation(aCont ? (ProxyMutex *)aCont->mutex : new_ProxyMutex()), cont(aCont), manipulate_fn(aManipulate_fn),
-    n_connections(2), lerrno(0), single_buffer(true), close_source(aclose_source), close_target(aclose_target),
-    tunnel_till_done(false), free_vcs(false)
+  : Continuation(aCont ? (ProxyMutex *)aCont->mutex : new_ProxyMutex()),
+    cont(aCont),
+    manipulate_fn(aManipulate_fn),
+    n_connections(2),
+    lerrno(0),
+    single_buffer(true),
+    close_source(aclose_source),
+    close_target(aclose_target),
+    tunnel_till_done(false),
+    free_vcs(false)
 {
   ink_assert(!"This form of OneWayTunnel() constructor not supported");
 }
diff --git a/lib/atscppapi/src/AsyncHttpFetch.cc b/lib/atscppapi/src/AsyncHttpFetch.cc
index 0ad46ad..01344a9 100644
--- a/lib/atscppapi/src/AsyncHttpFetch.cc
+++ b/lib/atscppapi/src/AsyncHttpFetch.cc
@@ -54,8 +54,14 @@ struct atscppapi::AsyncHttpFetchState : noncopyable {
 
   AsyncHttpFetchState(const string &url_str, HttpMethod http_method, string request_body,
                       AsyncHttpFetch::StreamingFlag streaming_flag)
-    : request_body_(request_body), result_(AsyncHttpFetch::RESULT_FAILURE), body_(NULL), body_size_(0), hdr_buf_(NULL),
-      hdr_loc_(NULL), streaming_flag_(streaming_flag), fetch_sm_(NULL)
+    : request_body_(request_body),
+      result_(AsyncHttpFetch::RESULT_FAILURE),
+      body_(NULL),
+      body_size_(0),
+      hdr_buf_(NULL),
+      hdr_loc_(NULL),
+      streaming_flag_(streaming_flag),
+      fetch_sm_(NULL)
   {
     request_.reset(new Request(url_str, http_method,
                                (streaming_flag_ == AsyncHttpFetch::STREAMING_DISABLED) ? HTTP_VERSION_1_0 : HTTP_VERSION_1_1));
diff --git a/lib/atscppapi/src/AsyncTimer.cc b/lib/atscppapi/src/AsyncTimer.cc
index baf7c67..1e40a02 100644
--- a/lib/atscppapi/src/AsyncTimer.cc
+++ b/lib/atscppapi/src/AsyncTimer.cc
@@ -35,8 +35,12 @@ struct atscppapi::AsyncTimerState {
   AsyncTimer *timer_;
   shared_ptr<AsyncDispatchControllerBase> dispatch_controller_;
   AsyncTimerState(AsyncTimer::Type type, int period_in_ms, int initial_period_in_ms, AsyncTimer *timer)
-    : type_(type), period_in_ms_(period_in_ms), initial_period_in_ms_(initial_period_in_ms), initial_timer_action_(NULL),
-      periodic_timer_action_(NULL), timer_(timer)
+    : type_(type),
+      period_in_ms_(period_in_ms),
+      initial_period_in_ms_(initial_period_in_ms),
+      initial_timer_action_(NULL),
+      periodic_timer_action_(NULL),
+      timer_(timer)
   {
   }
 };
diff --git a/lib/atscppapi/src/InterceptPlugin.cc b/lib/atscppapi/src/InterceptPlugin.cc
index 91a5b26..d51164a 100644
--- a/lib/atscppapi/src/InterceptPlugin.cc
+++ b/lib/atscppapi/src/InterceptPlugin.cc
@@ -85,8 +85,17 @@ struct InterceptPlugin::State {
   bool plugin_io_done_;
 
   State(TSCont cont, InterceptPlugin *plugin)
-    : cont_(cont), net_vc_(NULL), expected_body_size_(0), num_body_bytes_read_(0), hdr_parsed_(false), hdr_buf_(NULL),
-      hdr_loc_(NULL), num_bytes_written_(0), plugin_(plugin), timeout_action_(NULL), plugin_io_done_(false)
+    : cont_(cont),
+      net_vc_(NULL),
+      expected_body_size_(0),
+      num_body_bytes_read_(0),
+      hdr_parsed_(false),
+      hdr_buf_(NULL),
+      hdr_loc_(NULL),
+      num_bytes_written_(0),
+      plugin_(plugin),
+      timeout_action_(NULL),
+      plugin_io_done_(false)
   {
     plugin_mutex_ = plugin->getMutex();
     http_parser_ = TSHttpParserCreate();
diff --git a/lib/atscppapi/src/Logger.cc b/lib/atscppapi/src/Logger.cc
index 18c75c8..774e282 100644
--- a/lib/atscppapi/src/Logger.cc
+++ b/lib/atscppapi/src/Logger.cc
@@ -51,8 +51,13 @@ struct atscppapi::LoggerState : noncopyable {
   bool initialized_;
 
   LoggerState()
-    : add_timestamp_(false), rename_file_(false), level_(Logger::LOG_LEVEL_NO_LOG), rolling_enabled_(false),
-      rolling_interval_seconds_(-1), text_log_obj_(NULL), initialized_(false){};
+    : add_timestamp_(false),
+      rename_file_(false),
+      level_(Logger::LOG_LEVEL_NO_LOG),
+      rolling_enabled_(false),
+      rolling_interval_seconds_(-1),
+      text_log_obj_(NULL),
+      initialized_(false){};
   ~LoggerState(){};
 };
 
diff --git a/lib/atscppapi/src/Request.cc b/lib/atscppapi/src/Request.cc
index 300561a..9f417ab 100644
--- a/lib/atscppapi/src/Request.cc
+++ b/lib/atscppapi/src/Request.cc
@@ -42,7 +42,11 @@ struct atscppapi::RequestState : noncopyable {
   HttpVersion version_;
   bool destroy_buf_;
   RequestState()
-    : hdr_buf_(NULL), hdr_loc_(NULL), url_loc_(NULL), method_(HTTP_METHOD_UNKNOWN), version_(HTTP_VERSION_UNKNOWN),
+    : hdr_buf_(NULL),
+      hdr_loc_(NULL),
+      url_loc_(NULL),
+      method_(HTTP_METHOD_UNKNOWN),
+      version_(HTTP_VERSION_UNKNOWN),
       destroy_buf_(false)
   {
   }
diff --git a/lib/atscppapi/src/Transaction.cc b/lib/atscppapi/src/Transaction.cc
index 0e02d6c..560062a 100644
--- a/lib/atscppapi/src/Transaction.cc
+++ b/lib/atscppapi/src/Transaction.cc
@@ -61,10 +61,19 @@ struct atscppapi::TransactionState : noncopyable {
   map<string, shared_ptr<Transaction::ContextValue>> context_values_;
 
   TransactionState(TSHttpTxn txn, TSMBuffer client_request_hdr_buf, TSMLoc client_request_hdr_loc)
-    : txn_(txn), client_request_hdr_buf_(client_request_hdr_buf), client_request_hdr_loc_(client_request_hdr_loc),
-      client_request_(txn, client_request_hdr_buf, client_request_hdr_loc), server_request_hdr_buf_(NULL),
-      server_request_hdr_loc_(NULL), server_response_hdr_buf_(NULL), server_response_hdr_loc_(NULL), client_response_hdr_buf_(NULL),
-      client_response_hdr_loc_(NULL), cached_response_hdr_buf_(NULL), cached_response_hdr_loc_(NULL), cached_request_hdr_buf_(NULL),
+    : txn_(txn),
+      client_request_hdr_buf_(client_request_hdr_buf),
+      client_request_hdr_loc_(client_request_hdr_loc),
+      client_request_(txn, client_request_hdr_buf, client_request_hdr_loc),
+      server_request_hdr_buf_(NULL),
+      server_request_hdr_loc_(NULL),
+      server_response_hdr_buf_(NULL),
+      server_response_hdr_loc_(NULL),
+      client_response_hdr_buf_(NULL),
+      client_response_hdr_loc_(NULL),
+      cached_response_hdr_buf_(NULL),
+      cached_response_hdr_loc_(NULL),
+      cached_request_hdr_buf_(NULL),
       cached_request_hdr_loc_(NULL){};
 };
 
diff --git a/lib/atscppapi/src/TransformationPlugin.cc b/lib/atscppapi/src/TransformationPlugin.cc
index 5c48236..3be796e 100644
--- a/lib/atscppapi/src/TransformationPlugin.cc
+++ b/lib/atscppapi/src/TransformationPlugin.cc
@@ -60,8 +60,16 @@ struct atscppapi::TransformationPluginState : noncopyable {
 
   TransformationPluginState(atscppapi::Transaction &transaction, TransformationPlugin &transformation_plugin,
                             TransformationPlugin::Type type, TSHttpTxn txn)
-    : vconn_(NULL), transaction_(transaction), transformation_plugin_(transformation_plugin), type_(type), output_vio_(NULL),
-      txn_(txn), output_buffer_(NULL), output_buffer_reader_(NULL), bytes_written_(0), input_complete_dispatched_(false)
+    : vconn_(NULL),
+      transaction_(transaction),
+      transformation_plugin_(transformation_plugin),
+      type_(type),
+      output_vio_(NULL),
+      txn_(txn),
+      output_buffer_(NULL),
+      output_buffer_reader_(NULL),
+      bytes_written_(0),
+      input_complete_dispatched_(false)
   {
     output_buffer_ = TSIOBufferCreate();
     output_buffer_reader_ = TSIOBufferReaderAlloc(output_buffer_);
diff --git a/lib/records/RecHttp.cc b/lib/records/RecHttp.cc
index 32f8e12..8620044 100644
--- a/lib/records/RecHttp.cc
+++ b/lib/records/RecHttp.cc
@@ -146,8 +146,13 @@ HttpProxyPort::Group GLOBAL_DATA;
 HttpProxyPort::Group &HttpProxyPort::m_global = GLOBAL_DATA;
 
 HttpProxyPort::HttpProxyPort()
-  : m_fd(ts::NO_FD), m_type(TRANSPORT_DEFAULT), m_port(0), m_family(AF_INET), m_inbound_transparent_p(false),
-    m_outbound_transparent_p(false), m_transparent_passthrough(false)
+  : m_fd(ts::NO_FD),
+    m_type(TRANSPORT_DEFAULT),
+    m_port(0),
+    m_family(AF_INET),
+    m_inbound_transparent_p(false),
+    m_outbound_transparent_p(false),
+    m_transparent_passthrough(false)
 {
   memcpy(m_host_res_preference, host_res_default_preference_order, sizeof(m_host_res_preference));
 }
diff --git a/lib/ts/BaseLogFile.cc b/lib/ts/BaseLogFile.cc
index a3ca0c7..15793b8 100644
--- a/lib/ts/BaseLogFile.cc
+++ b/lib/ts/BaseLogFile.cc
@@ -48,9 +48,17 @@ BaseLogFile::BaseLogFile(const char *name, uint64_t sig) : m_signature(sig), m_h
  * This copy constructor creates a BaseLogFile based on a given copy.
  */
 BaseLogFile::BaseLogFile(const BaseLogFile &copy)
-  : m_fp(NULL), m_start_time(copy.m_start_time), m_end_time(0L), m_bytes_written(0), m_signature(copy.m_signature),
-    m_has_signature(copy.m_has_signature), m_name(ats_strdup(copy.m_name)), m_hostname(ats_strdup(copy.m_hostname)),
-    m_is_regfile(false), m_is_init(copy.m_is_init), m_meta_info(NULL)
+  : m_fp(NULL),
+    m_start_time(copy.m_start_time),
+    m_end_time(0L),
+    m_bytes_written(0),
+    m_signature(copy.m_signature),
+    m_has_signature(copy.m_has_signature),
+    m_name(ats_strdup(copy.m_name)),
+    m_hostname(ats_strdup(copy.m_hostname)),
+    m_is_regfile(false),
+    m_is_init(copy.m_is_init),
+    m_meta_info(NULL)
 {
   log_log_trace("exiting BaseLogFile copy constructor, m_name=%s, this=%p\n", m_name.get(), this);
 }
diff --git a/lib/ts/Diags.cc b/lib/ts/Diags.cc
index 3c6accd..67367fa 100644
--- a/lib/ts/Diags.cc
+++ b/lib/ts/Diags.cc
@@ -84,7 +84,12 @@ vprintline(FILE *fp, char (&buffer)[Size], va_list ap)
 //////////////////////////////////////////////////////////////////////////////
 
 Diags::Diags(const char *bdt, const char *bat, BaseLogFile *_diags_log)
-  : diags_log(NULL), stdout_log(NULL), stderr_log(NULL), magic(DIAGS_MAGIC), show_location(0), base_debug_tags(NULL),
+  : diags_log(NULL),
+    stdout_log(NULL),
+    stderr_log(NULL),
+    magic(DIAGS_MAGIC),
+    show_location(0),
+    base_debug_tags(NULL),
     base_action_tags(NULL)
 {
   int i;
diff --git a/lib/ts/ink_cap.cc b/lib/ts/ink_cap.cc
index 23c6f83..14be2ec 100644
--- a/lib/ts/ink_cap.cc
+++ b/lib/ts/ink_cap.cc
@@ -402,7 +402,9 @@ ElevateAccess::releasePrivilege()
 #endif
 
 ElevateAccess::ElevateAccess(unsigned lvl)
-  : elevated(false), saved_uid(geteuid()), level(lvl)
+  : elevated(false),
+    saved_uid(geteuid()),
+    level(lvl)
 #if TS_USE_POSIX_CAP
     ,
     cap_state(0)
diff --git a/mgmt/Rollback.cc b/mgmt/Rollback.cc
index a8e4487..aa68566 100644
--- a/mgmt/Rollback.cc
+++ b/mgmt/Rollback.cc
@@ -45,8 +45,13 @@ const char *RollbackStrings[] = {"Rollback Ok", "File was not found", "Version w
                                  "Invalid Version - Version Numbers Must Increase"};
 
 Rollback::Rollback(const char *fileName_, bool root_access_needed_, Rollback *parentRollback_, unsigned flags)
-  : configFiles(NULL), root_access_needed(root_access_needed_), parentRollback(parentRollback_), currentVersion(0),
-    fileLastModified(0), numVersions(0), numberBackups(0)
+  : configFiles(NULL),
+    root_access_needed(root_access_needed_),
+    parentRollback(parentRollback_),
+    currentVersion(0),
+    fileLastModified(0),
+    numVersions(0),
+    numberBackups(0)
 {
   version_t highestSeen;             // the highest backup version
   ExpandingArray existVer(25, true); // Exsisting versions
diff --git a/plugins/experimental/ats_pagespeed/ats_base_fetch.cc b/plugins/experimental/ats_pagespeed/ats_base_fetch.cc
index d8e0da0..0e717cf 100644
--- a/plugins/experimental/ats_pagespeed/ats_base_fetch.cc
+++ b/plugins/experimental/ats_pagespeed/ats_base_fetch.cc
@@ -38,12 +38,22 @@ using namespace net_instaweb;
 // TODO(oschaaf): rename is_resource_fetch -> write_raw_response_headers
 AtsBaseFetch::AtsBaseFetch(AtsServerContext *server_context, const net_instaweb::RequestContextPtr &request_ctx,
                            TSVIO downstream_vio, TSIOBuffer downstream_buffer, bool is_resource_fetch)
-  : AsyncFetch(request_ctx), server_context_(server_context), done_called_(false), last_buf_sent_(false), references_(2),
+  : AsyncFetch(request_ctx),
+    server_context_(server_context),
+    done_called_(false),
+    last_buf_sent_(false),
+    references_(2),
     // downstream_vio is NULL for the IPRO lookup
-    downstream_vio_(downstream_vio), downstream_buffer_(downstream_buffer), is_resource_fetch_(is_resource_fetch),
-    downstream_length_(0), txn_mutex_(downstream_vio ? TSVIOMutexGet(downstream_vio) : NULL),
+    downstream_vio_(downstream_vio),
+    downstream_buffer_(downstream_buffer),
+    is_resource_fetch_(is_resource_fetch),
+    downstream_length_(0),
+    txn_mutex_(downstream_vio ? TSVIOMutexGet(downstream_vio) : NULL),
     // TODO(oschaaf): check and use handle_error_.
-    handle_error_(false), is_ipro_(false), ctx_(NULL), ipro_callback_(NULL)
+    handle_error_(false),
+    is_ipro_(false),
+    ctx_(NULL),
+    ipro_callback_(NULL)
 {
   buffer_.reserve(1024 * 32);
 }
diff --git a/plugins/experimental/ats_pagespeed/ats_beacon_intercept.cc b/plugins/experimental/ats_pagespeed/ats_beacon_intercept.cc
index 18b2ed6..e59a79d 100644
--- a/plugins/experimental/ats_pagespeed/ats_beacon_intercept.cc
+++ b/plugins/experimental/ats_pagespeed/ats_beacon_intercept.cc
@@ -69,8 +69,16 @@ struct InterceptCtx {
   bool initialized;
   TransformCtx *request_context;
   InterceptCtx(TSCont cont)
-    : net_vc(0), contp(cont), input(), output(), body(""), req_content_len(0), req_hdr_bufp(0), req_hdr_loc(0),
-      req_hdr_parsed(false), initialized(false)
+    : net_vc(0),
+      contp(cont),
+      input(),
+      output(),
+      body(""),
+      req_content_len(0),
+      req_hdr_bufp(0),
+      req_hdr_loc(0),
+      req_hdr_parsed(false),
+      initialized(false)
   {
     http_parser = TSHttpParserCreate();
   }
diff --git a/plugins/experimental/ats_pagespeed/ats_resource_intercept.h b/plugins/experimental/ats_pagespeed/ats_resource_intercept.h
index bffda6e..0f7df30 100644
--- a/plugins/experimental/ats_pagespeed/ats_resource_intercept.h
+++ b/plugins/experimental/ats_pagespeed/ats_resource_intercept.h
@@ -48,8 +48,14 @@ struct InterceptCtx {
   RequestHeaders *request_headers;
 
   InterceptCtx()
-    : vconn(NULL), req_buffer(NULL), req_reader(NULL), resp_buffer(NULL), resp_reader(NULL), response(new GoogleString()),
-      request_ctx(NULL), request_headers(NULL){};
+    : vconn(NULL),
+      req_buffer(NULL),
+      req_reader(NULL),
+      resp_buffer(NULL),
+      resp_reader(NULL),
+      response(new GoogleString()),
+      request_ctx(NULL),
+      request_headers(NULL){};
 };
 
 void setup_resource_intercept();
diff --git a/plugins/experimental/ats_pagespeed/ats_rewrite_driver_factory.cc b/plugins/experimental/ats_pagespeed/ats_rewrite_driver_factory.cc
index 3fd3bc3..b1c78c7 100644
--- a/plugins/experimental/ats_pagespeed/ats_rewrite_driver_factory.cc
+++ b/plugins/experimental/ats_pagespeed/ats_rewrite_driver_factory.cc
@@ -63,7 +63,8 @@ AtsRewriteDriverFactory::AtsRewriteDriverFactory(const ProcessContext &process_c
   : SystemRewriteDriverFactory(process_context, thread_system, NULL /*default shared mem runtime*/, "" /*hostname, not used*/,
                                -1 /*port, not used*/),
     ats_message_handler_(new AtsMessageHandler(thread_system->NewMutex())),
-    ats_html_parse_message_handler_(new AtsMessageHandler(thread_system->NewMutex())), use_per_vhost_statistics_(false),
+    ats_html_parse_message_handler_(new AtsMessageHandler(thread_system->NewMutex())),
+    use_per_vhost_statistics_(false),
     threads_started_(false)
 {
   InitializeDefaultOptions();
diff --git a/plugins/experimental/ats_pagespeed/ats_rewrite_options.h b/plugins/experimental/ats_pagespeed/ats_rewrite_options.h
index 502442c..4d1a9c6 100644
--- a/plugins/experimental/ats_pagespeed/ats_rewrite_options.h
+++ b/plugins/experimental/ats_pagespeed/ats_rewrite_options.h
@@ -40,7 +40,10 @@ class ThreadSystem;
 
 struct global_settings {
   global_settings()
-    : info_urls_local_only(true), use_native_fetcher(false), use_per_vhost_statistics(true), message_buffer_size(1024 * 128),
+    : info_urls_local_only(true),
+      use_native_fetcher(false),
+      use_per_vhost_statistics(true),
+      message_buffer_size(1024 * 128),
       shm_cache_size_kb(0)
   //, rate_limit_background_fetches(true)
   //, force_caching(false)
diff --git a/plugins/experimental/ats_pagespeed/ats_server_context.cc b/plugins/experimental/ats_pagespeed/ats_server_context.cc
index d13d393..73559fe 100644
--- a/plugins/experimental/ats_pagespeed/ats_server_context.cc
+++ b/plugins/experimental/ats_pagespeed/ats_server_context.cc
@@ -38,7 +38,8 @@ AtsServerContext::config()
 AtsServerContext::AtsServerContext(AtsRewriteDriverFactory *factory)
   : // TODO(oschaaf): host/port
     SystemServerContext(factory, "foo.com" /*hostname*/, 8080 /*port*/),
-    initialized_(false), ats_factory_(factory)
+    initialized_(false),
+    ats_factory_(factory)
 {
 }
 
diff --git a/plugins/experimental/authproxy/authproxy.cc b/plugins/experimental/authproxy/authproxy.cc
index ca40600..1fa7a6c 100644
--- a/plugins/experimental/authproxy/authproxy.cc
+++ b/plugins/experimental/authproxy/authproxy.cc
@@ -151,8 +151,15 @@ struct AuthRequestContext {
   const StateTransition *state;
 
   AuthRequestContext()
-    : txn(NULL), cont(NULL), vconn(NULL), hparser(TSHttpParserCreate()), rheader(), iobuf(TS_IOBUFFER_SIZE_INDEX_4K), method(NULL),
-      read_body(true), state(NULL)
+    : txn(NULL),
+      cont(NULL),
+      vconn(NULL),
+      hparser(TSHttpParserCreate()),
+      rheader(),
+      iobuf(TS_IOBUFFER_SIZE_INDEX_4K),
+      method(NULL),
+      read_body(true),
+      state(NULL)
   {
     this->cont = TSContCreate(dispatch, TSMutexCreate());
     TSContDataSet(this->cont, this);
diff --git a/plugins/experimental/background_fetch/background_fetch.cc b/plugins/experimental/background_fetch/background_fetch.cc
index 6e60b4e..013e4d5 100644
--- a/plugins/experimental/background_fetch/background_fetch.cc
+++ b/plugins/experimental/background_fetch/background_fetch.cc
@@ -121,8 +121,17 @@ private:
 // during the time we fetch from origin.
 struct BgFetchData {
   BgFetchData()
-    : hdr_loc(TS_NULL_MLOC), url_loc(TS_NULL_MLOC), vc(NULL), req_io_buf(NULL), resp_io_buf(NULL), req_io_buf_reader(NULL),
-      resp_io_buf_reader(NULL), r_vio(NULL), w_vio(NULL), _bytes(0), _cont(NULL)
+    : hdr_loc(TS_NULL_MLOC),
+      url_loc(TS_NULL_MLOC),
+      vc(NULL),
+      req_io_buf(NULL),
+      resp_io_buf(NULL),
+      req_io_buf_reader(NULL),
+      resp_io_buf_reader(NULL),
+      r_vio(NULL),
+      w_vio(NULL),
+      _bytes(0),
+      _cont(NULL)
   {
     mbuf = TSMBufferCreate();
     memset(&client_ip, 0, sizeof(client_ip));
diff --git a/plugins/experimental/esi/combo_handler.cc b/plugins/experimental/esi/combo_handler.cc
index a4bad01..df664f4 100644
--- a/plugins/experimental/esi/combo_handler.cc
+++ b/plugins/experimental/esi/combo_handler.cc
@@ -115,8 +115,17 @@ struct InterceptData {
   string gzipped_data;
 
   InterceptData(TSCont cont)
-    : net_vc(0), contp(cont), input(), output(), req_hdr_bufp(0), req_hdr_loc(0), req_hdr_parsed(false), initialized(false),
-      fetcher(0), read_complete(false), write_complete(false)
+    : net_vc(0),
+      contp(cont),
+      input(),
+      output(),
+      req_hdr_bufp(0),
+      req_hdr_loc(0),
+      req_hdr_parsed(false),
+      initialized(false),
+      fetcher(0),
+      read_complete(false),
+      write_complete(false)
   {
     http_parser = TSHttpParserCreate();
   }
diff --git a/plugins/experimental/esi/esi.cc b/plugins/experimental/esi/esi.cc
index 54e60bd..2583d2a 100644
--- a/plugins/experimental/esi/esi.cc
+++ b/plugins/experimental/esi/esi.cc
@@ -125,10 +125,29 @@ struct ContData {
   list<string> post_headers;
 
   ContData(TSCont contptr, TSHttpTxn tx)
-    : curr_state(READING_ESI_DOC), input_vio(NULL), output_vio(NULL), output_buffer(NULL), output_reader(NULL), esi_vars(NULL),
-      data_fetcher(NULL), esi_proc(NULL), esi_gzip(NULL), esi_gunzip(NULL), contp(contptr), txnp(tx), request_url(NULL),
-      input_type(DATA_TYPE_RAW_ESI), packed_node_list(""), gzipped_data(""), gzip_output(false), initialized(false),
-      xform_closed(false), intercept_header(false), cache_txn(false), head_only(false), os_response_cacheable(true)
+    : curr_state(READING_ESI_DOC),
+      input_vio(NULL),
+      output_vio(NULL),
+      output_buffer(NULL),
+      output_reader(NULL),
+      esi_vars(NULL),
+      data_fetcher(NULL),
+      esi_proc(NULL),
+      esi_gzip(NULL),
+      esi_gunzip(NULL),
+      contp(contptr),
+      txnp(tx),
+      request_url(NULL),
+      input_type(DATA_TYPE_RAW_ESI),
+      packed_node_list(""),
+      gzipped_data(""),
+      gzip_output(false),
+      initialized(false),
+      xform_closed(false),
+      intercept_header(false),
+      cache_txn(false),
+      head_only(false),
+      os_response_cacheable(true)
   {
     client_addr = TSHttpTxnClientAddrGet(txnp);
     *debug_tag = '\0';
diff --git a/plugins/experimental/esi/lib/EsiProcessor.cc b/plugins/experimental/esi/lib/EsiProcessor.cc
index 362a729..e2633a5 100644
--- a/plugins/experimental/esi/lib/EsiProcessor.cc
+++ b/plugins/experimental/esi/lib/EsiProcessor.cc
@@ -37,10 +37,20 @@ const char *EsiProcessor::INCLUDE_DATA_ID_ATTR = reinterpret_cast<const char *>(
 EsiProcessor::EsiProcessor(const char *debug_tag, const char *parser_debug_tag, const char *expression_debug_tag,
                            ComponentBase::Debug debug_func, ComponentBase::Error error_func, HttpDataFetcher &fetcher,
                            Variables &variables, const HandlerManager &handler_mgr)
-  : ComponentBase(debug_tag, debug_func, error_func), _curr_state(STOPPED), _parser(parser_debug_tag, debug_func, error_func),
-    _n_prescanned_nodes(0), _n_processed_nodes(0), _n_processed_try_nodes(0), _overall_len(0), _fetcher(fetcher), _reqAdded(false),
-    _usePackedNodeList(false), _esi_vars(variables), _expression(expression_debug_tag, debug_func, error_func, _esi_vars),
-    _n_try_blocks_processed(0), _handler_manager(handler_mgr)
+  : ComponentBase(debug_tag, debug_func, error_func),
+    _curr_state(STOPPED),
+    _parser(parser_debug_tag, debug_func, error_func),
+    _n_prescanned_nodes(0),
+    _n_processed_nodes(0),
+    _n_processed_try_nodes(0),
+    _overall_len(0),
+    _fetcher(fetcher),
+    _reqAdded(false),
+    _usePackedNodeList(false),
+    _esi_vars(variables),
+    _expression(expression_debug_tag, debug_func, error_func, _esi_vars),
+    _n_try_blocks_processed(0),
+    _handler_manager(handler_mgr)
 {
 }
 
diff --git a/plugins/experimental/esi/lib/Variables.h b/plugins/experimental/esi/lib/Variables.h
index 8f321c7..64edd64 100644
--- a/plugins/experimental/esi/lib/Variables.h
+++ b/plugins/experimental/esi/lib/Variables.h
@@ -38,7 +38,10 @@ class Variables : private ComponentBase
 {
 public:
   Variables(const char *debug_tag, ComponentBase::Debug debug_func, ComponentBase::Error error_func)
-    : ComponentBase(debug_tag, debug_func, error_func), _headers_parsed(false), _query_string(""), _query_string_parsed(false),
+    : ComponentBase(debug_tag, debug_func, error_func),
+      _headers_parsed(false),
+      _query_string(""),
+      _query_string_parsed(false),
       _cookie_jar_created(false){};
 
   /** currently 'host', 'referer', 'accept-language', 'cookie' and 'user-agent' headers are parsed */
diff --git a/plugins/experimental/esi/serverIntercept.cc b/plugins/experimental/esi/serverIntercept.cc
index 56989d2..e553cd2 100644
--- a/plugins/experimental/esi/serverIntercept.cc
+++ b/plugins/experimental/esi/serverIntercept.cc
@@ -70,8 +70,16 @@ struct SContData {
   bool initialized;
 
   SContData(TSCont cont)
-    : net_vc(0), contp(cont), input(), output(), body(""), req_content_len(0), req_hdr_bufp(0), req_hdr_loc(0),
-      req_hdr_parsed(false), initialized(false)
+    : net_vc(0),
+      contp(cont),
+      input(),
+      output(),
+      body(""),
+      req_content_len(0),
+      req_hdr_bufp(0),
+      req_hdr_loc(0),
+      req_hdr_parsed(false),
+      initialized(false)
   {
     http_parser = TSHttpParserCreate();
   }
diff --git a/plugins/experimental/hipes/hipes.cc b/plugins/experimental/hipes/hipes.cc
index 32a3ca5..f1b8b2e 100644
--- a/plugins/experimental/hipes/hipes.cc
+++ b/plugins/experimental/hipes/hipes.cc
@@ -124,9 +124,19 @@ unescapify(const char *src, char *dst, int len)
 //
 struct HIPESService {
   HIPESService()
-    : url_param("url"), path(""), svc_server(""), svc_port(80), ssl(false), hipes_server(HIPES_SERVER_NAME), hipes_port(80),
-      default_redirect_flag(1), x_hipes_header("X-HIPES-Redirect"), active_timeout(-1), no_activity_timeout(-1),
-      connect_timeout(-1), dns_timeout(-1){};
+    : url_param("url"),
+      path(""),
+      svc_server(""),
+      svc_port(80),
+      ssl(false),
+      hipes_server(HIPES_SERVER_NAME),
+      hipes_port(80),
+      default_redirect_flag(1),
+      x_hipes_header("X-HIPES-Redirect"),
+      active_timeout(-1),
+      no_activity_timeout(-1),
+      connect_timeout(-1),
+      dns_timeout(-1){};
 
   std::string url_param;
   std::string path;
diff --git a/plugins/experimental/inliner/cache-handler.h b/plugins/experimental/inliner/cache-handler.h
index 467c089..c55d374 100644
--- a/plugins/experimental/inliner/cache-handler.h
+++ b/plugins/experimental/inliner/cache-handler.h
@@ -233,8 +233,13 @@ namespace inliner
     }
 
     CacheHandler(CacheHandler &&h)
-      : src_(std::move(h.src_)), original_(std::move(h.original_)), classes_(std::move(h.classes_)), id_(std::move(h.id_)),
-        sink_(std::move(h.sink_)), sink2_(std::move(h.sink2_)), reader_(h.reader_)
+      : src_(std::move(h.src_)),
+        original_(std::move(h.original_)),
+        classes_(std::move(h.classes_)),
+        id_(std::move(h.id_)),
+        sink_(std::move(h.sink_)),
+        sink2_(std::move(h.sink2_)),
+        reader_(h.reader_)
     {
       h.reader_ = NULL;
     }
diff --git a/plugins/experimental/inliner/fetcher.h b/plugins/experimental/inliner/fetcher.h
index ffa72df..1b72ec6 100644
--- a/plugins/experimental/inliner/fetcher.h
+++ b/plugins/experimental/inliner/fetcher.h
@@ -130,7 +130,14 @@ template <class T> struct HttpTransaction {
   }
 
   HttpTransaction(TSVConn v, TSCont c, io::IO *const i, const uint64_t l, const T &t)
-    : parsingHeaders_(false), abort_(false), timeout_(false), in_(NULL), out_(i), vconnection_(v), continuation_(c), t_(t),
+    : parsingHeaders_(false),
+      abort_(false),
+      timeout_(false),
+      in_(NULL),
+      out_(i),
+      vconnection_(v),
+      continuation_(c),
+      t_(t),
       chunkDecoder_(NULL)
   {
     assert(vconnection_ != NULL);
diff --git a/plugins/experimental/inliner/ts.cc b/plugins/experimental/inliner/ts.cc
index a741626..81a15e1 100644
--- a/plugins/experimental/inliner/ts.cc
+++ b/plugins/experimental/inliner/ts.cc
@@ -104,9 +104,15 @@ namespace io
   }
 
   WriteOperation::WriteOperation(const TSVConn v, const TSMutex m, const size_t t)
-    : vconnection_(v), buffer_(TSIOBufferCreate()), reader_(TSIOBufferReaderAlloc(buffer_)),
-      mutex_(m != NULL ? m : TSMutexCreate()), continuation_(TSContCreate(WriteOperation::Handle, mutex_)),
-      vio_(TSVConnWrite(v, continuation_, reader_, std::numeric_limits<int64_t>::max())), action_(NULL), timeout_(t), bytes_(0),
+    : vconnection_(v),
+      buffer_(TSIOBufferCreate()),
+      reader_(TSIOBufferReaderAlloc(buffer_)),
+      mutex_(m != NULL ? m : TSMutexCreate()),
+      continuation_(TSContCreate(WriteOperation::Handle, mutex_)),
+      vio_(TSVConnWrite(v, continuation_, reader_, std::numeric_limits<int64_t>::max())),
+      action_(NULL),
+      timeout_(t),
+      bytes_(0),
       reenable_(true)
   {
     assert(vconnection_ != NULL);
diff --git a/plugins/experimental/mp4/mp4_meta.h b/plugins/experimental/mp4/mp4_meta.h
index 0631851..c43d6bf 100644
--- a/plugins/experimental/mp4/mp4_meta.h
+++ b/plugins/experimental/mp4/mp4_meta.h
@@ -335,9 +335,25 @@ class Mp4Trak
 {
 public:
   Mp4Trak()
-    : timescale(0), duration(0), time_to_sample_entries(0), sample_to_chunk_entries(0), sync_samples_entries(0),
-      composition_offset_entries(0), sample_sizes_entries(0), chunks(0), start_sample(0), start_chunk(0), chunk_samples(0),
-      chunk_samples_size(0), start_offset(0), tkhd_size(0), mdhd_size(0), hdlr_size(0), vmhd_size(0), smhd_size(0), dinf_size(0),
+    : timescale(0),
+      duration(0),
+      time_to_sample_entries(0),
+      sample_to_chunk_entries(0),
+      sync_samples_entries(0),
+      composition_offset_entries(0),
+      sample_sizes_entries(0),
+      chunks(0),
+      start_sample(0),
+      start_chunk(0),
+      chunk_samples(0),
+      chunk_samples_size(0),
+      start_offset(0),
+      tkhd_size(0),
+      mdhd_size(0),
+      hdlr_size(0),
+      vmhd_size(0),
+      smhd_size(0),
+      dinf_size(0),
       size(0)
   {
     memset(&stsc_chunk_entry, 0, sizeof(mp4_stsc_entry));
@@ -378,8 +394,22 @@ class Mp4Meta
 {
 public:
   Mp4Meta()
-    : start(0), cl(0), content_length(0), meta_atom_size(0), meta_avail(0), wait_next(0), need_size(0), rs(0), rate(0),
-      ftyp_size(0), moov_size(0), start_pos(0), timescale(0), trak_num(0), passed(0), meta_complete(false)
+    : start(0),
+      cl(0),
+      content_length(0),
+      meta_atom_size(0),
+      meta_avail(0),
+      wait_next(0),
+      need_size(0),
+      rs(0),
+      rate(0),
+      ftyp_size(0),
+      moov_size(0),
+      start_pos(0),
+      timescale(0),
+      trak_num(0),
+      passed(0),
+      meta_complete(false)
   {
     memset(trak_vec, 0, sizeof(trak_vec));
     meta_buffer = TSIOBufferCreate();
diff --git a/plugins/experimental/multiplexer/fetcher.h b/plugins/experimental/multiplexer/fetcher.h
index 13598c7..96798eb 100644
--- a/plugins/experimental/multiplexer/fetcher.h
+++ b/plugins/experimental/multiplexer/fetcher.h
@@ -109,7 +109,14 @@ template <class T> struct HttpTransaction {
   }
 
   HttpTransaction(TSVConn v, TSCont c, io::IO *const i, const uint64_t l, const T &t)
-    : parsingHeaders_(false), abort_(false), timeout_(false), in_(NULL), out_(i), vconnection_(v), continuation_(c), t_(t),
+    : parsingHeaders_(false),
+      abort_(false),
+      timeout_(false),
+      in_(NULL),
+      out_(i),
+      vconnection_(v),
+      continuation_(c),
+      t_(t),
       chunkDecoder_(NULL)
   {
     assert(vconnection_ != NULL);
diff --git a/plugins/header_rewrite/resources.h b/plugins/header_rewrite/resources.h
index 3ed6250..ca90fb1 100644
--- a/plugins/header_rewrite/resources.h
+++ b/plugins/header_rewrite/resources.h
@@ -52,15 +52,31 @@ class Resources
 {
 public:
   explicit Resources(TSHttpTxn txnptr, TSCont contptr)
-    : txnp(txnptr), contp(contptr), bufp(NULL), hdr_loc(NULL), client_bufp(NULL), client_hdr_loc(NULL),
-      resp_status(TS_HTTP_STATUS_NONE), _rri(NULL), changed_url(false), _ready(false)
+    : txnp(txnptr),
+      contp(contptr),
+      bufp(NULL),
+      hdr_loc(NULL),
+      client_bufp(NULL),
+      client_hdr_loc(NULL),
+      resp_status(TS_HTTP_STATUS_NONE),
+      _rri(NULL),
+      changed_url(false),
+      _ready(false)
   {
     TSDebug(PLUGIN_NAME_DBG, "Calling CTOR for Resources (InkAPI)");
   }
 
   Resources(TSHttpTxn txnptr, TSRemapRequestInfo *rri)
-    : txnp(txnptr), contp(NULL), bufp(NULL), hdr_loc(NULL), client_bufp(NULL), client_hdr_loc(NULL),
-      resp_status(TS_HTTP_STATUS_NONE), _rri(rri), changed_url(false), _ready(false)
+    : txnp(txnptr),
+      contp(NULL),
+      bufp(NULL),
+      hdr_loc(NULL),
+      client_bufp(NULL),
+      client_hdr_loc(NULL),
+      resp_status(TS_HTTP_STATUS_NONE),
+      _rri(rri),
+      changed_url(false),
+      _ready(false)
   {
     TSDebug(PLUGIN_NAME_DBG, "Calling CTOR for Resources (RemapAPI)");
   }
diff --git a/plugins/header_rewrite/ruleset.h b/plugins/header_rewrite/ruleset.h
index 1a716de..dd67ffa 100644
--- a/plugins/header_rewrite/ruleset.h
+++ b/plugins/header_rewrite/ruleset.h
@@ -37,7 +37,12 @@ class RuleSet
 {
 public:
   RuleSet()
-    : next(NULL), _cond(NULL), _oper(NULL), _hook(TS_HTTP_READ_RESPONSE_HDR_HOOK), _ids(RSRC_NONE), _opermods(OPER_NONE),
+    : next(NULL),
+      _cond(NULL),
+      _oper(NULL),
+      _hook(TS_HTTP_READ_RESPONSE_HDR_HOOK),
+      _ids(RSRC_NONE),
+      _opermods(OPER_NONE),
       _last(false){};
 
   // No reason to inline these
diff --git a/plugins/regex_remap/regex_remap.cc b/plugins/regex_remap/regex_remap.cc
index afceab5..a5960d9 100644
--- a/plugins/regex_remap/regex_remap.cc
+++ b/plugins/regex_remap/regex_remap.cc
@@ -73,8 +73,18 @@ enum ExtraSubstitutions {
 //
 struct UrlComponents {
   UrlComponents()
-    : scheme(NULL), host(NULL), path(NULL), query(NULL), matrix(NULL), port(0), scheme_len(0), host_len(0), path_len(0),
-      query_len(0), matrix_len(0), url_len(0)
+    : scheme(NULL),
+      host(NULL),
+      path(NULL),
+      query(NULL),
+      matrix(NULL),
+      port(0),
+      scheme_len(0),
+      host_len(0),
+      path_len(0),
+      query_len(0),
+      matrix_len(0),
+      url_len(0)
   {
   }
 
@@ -114,8 +124,17 @@ class RemapRegex
 {
 public:
   RemapRegex()
-    : _num_subs(-1), _rex(NULL), _extra(NULL), _options(0), _order(-1), _lowercase_substitutions(false), _active_timeout(-1),
-      _no_activity_timeout(-1), _connect_timeout(-1), _dns_timeout(-1), _first_override(NULL)
+    : _num_subs(-1),
+      _rex(NULL),
+      _extra(NULL),
+      _options(0),
+      _order(-1),
+      _lowercase_substitutions(false),
+      _active_timeout(-1),
+      _no_activity_timeout(-1),
+      _connect_timeout(-1),
+      _dns_timeout(-1),
+      _first_override(NULL)
   {
     TSDebug(PLUGIN_NAME, "Calling constructor");
   }
@@ -636,7 +655,14 @@ RemapRegex::substitute(char dest[], const char *src, const int ovector[], const
 // Hold one remap instance
 struct RemapInstance {
   RemapInstance()
-    : first(NULL), last(NULL), profile(false), method(false), query_string(true), matrix_params(false), hits(0), misses(0),
+    : first(NULL),
+      last(NULL),
+      profile(false),
+      method(false),
+      query_string(true),
+      matrix_params(false),
+      hits(0),
+      misses(0),
       filename("unknown")
   {
   }
diff --git a/proxy/CacheControl.h b/proxy/CacheControl.h
index 059c546..259eea5 100644
--- a/proxy/CacheControl.h
+++ b/proxy/CacheControl.h
@@ -100,10 +100,21 @@ public:
 };
 
 inline CacheControlResult::CacheControlResult()
-  : revalidate_after(CC_UNSET_TIME), pin_in_cache_for(CC_UNSET_TIME), ttl_in_cache(CC_UNSET_TIME), never_cache(false),
-    cluster_cache_local(false), ignore_client_no_cache(false), ignore_server_no_cache(false), ignore_client_cc_max_age(true),
+  : revalidate_after(CC_UNSET_TIME),
+    pin_in_cache_for(CC_UNSET_TIME),
+    ttl_in_cache(CC_UNSET_TIME),
+    never_cache(false),
+    cluster_cache_local(false),
+    ignore_client_no_cache(false),
+    ignore_server_no_cache(false),
+    ignore_client_cc_max_age(true),
     cache_responses_to_cookies(-1), // do not change value
-    reval_line(-1), never_line(-1), pin_line(-1), ttl_line(-1), cluster_cache_local_line(-1), ignore_client_line(-1),
+    reval_line(-1),
+    never_line(-1),
+    pin_line(-1),
+    ttl_line(-1),
+    cluster_cache_local_line(-1),
+    ignore_client_line(-1),
     ignore_server_line(-1)
 {
 }
diff --git a/proxy/ControlMatcher.cc b/proxy/ControlMatcher.cc
index 7f0fd60..50d4020 100644
--- a/proxy/ControlMatcher.cc
+++ b/proxy/ControlMatcher.cc
@@ -237,7 +237,13 @@ HostMatcher<Data, Result>::NewEntry(matcher_line *line_info)
 //
 template <class Data, class Result>
 UrlMatcher<Data, Result>::UrlMatcher(const char *name, const char *filename)
-  : url_ht(NULL), url_str(NULL), url_value(NULL), data_array(NULL), array_len(0), num_el(-1), matcher_name(name),
+  : url_ht(NULL),
+    url_str(NULL),
+    url_value(NULL),
+    data_array(NULL),
+    array_len(0),
+    num_el(-1),
+    matcher_name(name),
     file_name(filename)
 {
   url_ht = ink_hash_table_create(InkHashTableKeyType_String);
diff --git a/proxy/ICP.cc b/proxy/ICP.cc
index 172ce02..5442331 100644
--- a/proxy/ICP.cc
+++ b/proxy/ICP.cc
@@ -282,8 +282,15 @@ ICPPeerReadCont::PeerReadData::reset(int full_reset)
 // ICPPeerReadCont -- ICP incoming message processing state machine
 //------------------------------------------------------------------------
 ICPPeerReadCont::ICPPeerReadCont()
-  : Continuation(0), _object_vc(NULL), _object_read(NULL), _cache_req_hdr_heap_handle(NULL), _cache_resp_hdr_heap_handle(NULL),
-    _ICPpr(NULL), _state(NULL), _start_time(0), _recursion_depth(0)
+  : Continuation(0),
+    _object_vc(NULL),
+    _object_read(NULL),
+    _cache_req_hdr_heap_handle(NULL),
+    _cache_resp_hdr_heap_handle(NULL),
+    _ICPpr(NULL),
+    _state(NULL),
+    _start_time(0),
+    _recursion_depth(0)
 {
 }
 
@@ -960,8 +967,18 @@ ICPPeerReadCont::PeerReadStateMachine(PeerReadData *s, Event *e)
 ClassAllocator<ICPRequestCont> ICPRequestCont_allocator("ICPRequestCont_allocator");
 
 ICPRequestCont::ICPRequestCont(ICPProcessor *pr, Continuation *c, URL *u)
-  : Continuation(0), _cont(c), _url(u), _start_time(0), _ICPpr(pr), _timeout(0), npending_actions(0), pendingActions(NULL),
-    _sequence_number(0), _expected_replies(0), _expected_replies_list(MAX_DEFINED_PEERS), _received_replies(0),
+  : Continuation(0),
+    _cont(c),
+    _url(u),
+    _start_time(0),
+    _ICPpr(pr),
+    _timeout(0),
+    npending_actions(0),
+    pendingActions(NULL),
+    _sequence_number(0),
+    _expected_replies(0),
+    _expected_replies_list(MAX_DEFINED_PEERS),
+    _received_replies(0),
     _next_state(ICP_START)
 {
   memset((void *)&_ret_sockaddr, 0, sizeof(_ret_sockaddr));
@@ -1682,9 +1699,25 @@ ICPProcessor icpProcessorInternal;
 ICPProcessorExt icpProcessor(&icpProcessorInternal);
 
 ICPProcessor::ICPProcessor()
-  : _l(0), _Initialized(0), _AllowIcpQueries(0), _PendingIcpQueries(0), _ICPConfig(0), _ICPPeriodic(0), _ICPHandler(0),
-    _mcastCB_handler(NULL), _PeriodicEvent(0), _ICPHandlerEvent(0), _nPeerList(-1), _LocalPeer(0), _curSendPeer(0),
-    _nSendPeerList(-1), _curRecvPeer(0), _nRecvPeerList(-1), _curParentPeer(0), _nParentPeerList(-1), _ValidPollData(0),
+  : _l(0),
+    _Initialized(0),
+    _AllowIcpQueries(0),
+    _PendingIcpQueries(0),
+    _ICPConfig(0),
+    _ICPPeriodic(0),
+    _ICPHandler(0),
+    _mcastCB_handler(NULL),
+    _PeriodicEvent(0),
+    _ICPHandlerEvent(0),
+    _nPeerList(-1),
+    _LocalPeer(0),
+    _curSendPeer(0),
+    _nSendPeerList(-1),
+    _curRecvPeer(0),
+    _nRecvPeerList(-1),
+    _curParentPeer(0),
+    _nParentPeerList(-1),
+    _ValidPollData(0),
     _last_recv_peer_bias(0)
 {
   memset((void *)_PeerList, 0, sizeof(_PeerList[PEER_LIST_SIZE]));
diff --git a/proxy/ICP.h b/proxy/ICP.h
index 29a4be4..f90e9f8 100644
--- a/proxy/ICP.h
+++ b/proxy/ICP.h
@@ -234,8 +234,16 @@ class ICPConfigData
 
 public:
   ICPConfigData()
-    : _icp_enabled(0), _icp_port(0), _icp_interface(0), _multicast_enabled(0), _icp_query_timeout(0), _cache_lookup_local(0),
-      _stale_lookup(0), _reply_to_unknown_peer(0), _default_reply_port(0), _cache_generation(-1)
+    : _icp_enabled(0),
+      _icp_port(0),
+      _icp_interface(0),
+      _multicast_enabled(0),
+      _icp_query_timeout(0),
+      _cache_lookup_local(0),
+      _stale_lookup(0),
+      _reply_to_unknown_peer(0),
+      _default_reply_port(0),
+      _cache_generation(-1)
   {
   }
   ~ICPConfigData() {} // Note: _icp_interface freed prior to delete
@@ -318,7 +326,12 @@ class PeerConfigData
 public:
   PeerConfigData();
   PeerConfigData(int ctype, IpAddr const &ip_addr, int proxy_port, int icp_port)
-    : _ctype(ctype), _ip_addr(ip_addr), _proxy_port(proxy_port), _icp_port(icp_port), _mc_member(0), _mc_ttl(0),
+    : _ctype(ctype),
+      _ip_addr(ip_addr),
+      _proxy_port(proxy_port),
+      _icp_port(icp_port),
+      _mc_member(0),
+      _mc_ttl(0),
       _my_ip_addr(ip_addr)
   {
     _hostname[0] = 0;
diff --git a/proxy/IPAllow.h b/proxy/IPAllow.h
index fdb9037..5fee699 100644
--- a/proxy/IPAllow.h
+++ b/proxy/IPAllow.h
@@ -66,7 +66,9 @@ struct AclRecord {
   AclRecord() : _method_mask(0), _src_line(0), _deny_nonstandard_methods(false) {}
   AclRecord(uint32_t method_mask) : _method_mask(method_mask), _src_line(0), _deny_nonstandard_methods(false) {}
   AclRecord(uint32_t method_mask, int ln, const MethodSet &nonstandard_methods, bool deny_nonstandard_methods)
-    : _method_mask(method_mask), _src_line(ln), _nonstandard_methods(nonstandard_methods),
+    : _method_mask(method_mask),
+      _src_line(ln),
+      _nonstandard_methods(nonstandard_methods),
       _deny_nonstandard_methods(deny_nonstandard_methods)
   {
   }
diff --git a/proxy/InkAPI.cc b/proxy/InkAPI.cc
index 3720b19..00b544d 100644
--- a/proxy/InkAPI.cc
+++ b/proxy/InkAPI.cc
@@ -919,14 +919,26 @@ FileImpl::fgets(char *buf, int length)
 ////////////////////////////////////////////////////////////////////
 
 INKContInternal::INKContInternal()
-  : DummyVConnection(NULL), mdata(NULL), m_event_func(NULL), m_event_count(0), m_closed(1), m_deletable(0), m_deleted(0),
+  : DummyVConnection(NULL),
+    mdata(NULL),
+    m_event_func(NULL),
+    m_event_count(0),
+    m_closed(1),
+    m_deletable(0),
+    m_deleted(0),
     m_free_magic(INKCONT_INTERN_MAGIC_ALIVE)
 {
 }
 
 INKContInternal::INKContInternal(TSEventFunc funcp, TSMutex mutexp)
-  : DummyVConnection((ProxyMutex *)mutexp), mdata(NULL), m_event_func(funcp), m_event_count(0), m_closed(1), m_deletable(0),
-    m_deleted(0), m_free_magic(INKCONT_INTERN_MAGIC_ALIVE)
+  : DummyVConnection((ProxyMutex *)mutexp),
+    mdata(NULL),
+    m_event_func(funcp),
+    m_event_count(0),
+    m_closed(1),
+    m_deletable(0),
+    m_deleted(0),
+    m_free_magic(INKCONT_INTERN_MAGIC_ALIVE)
 {
   SET_HANDLER(&INKContInternal::handle_event);
 }
diff --git a/proxy/Main.cc b/proxy/Main.cc
index eec06d9..e99d41d 100644
--- a/proxy/Main.cc
+++ b/proxy/Main.cc
@@ -1170,8 +1170,19 @@ struct ShowStats : public Continuation {
     return EVENT_CONT;
   }
   ShowStats()
-    : Continuation(NULL), cycle(0), last_cc(0), last_rb(0), last_w(0), last_r(0), last_wb(0), last_nrb(0), last_nw(0), last_nr(0),
-      last_nwb(0), last_p(0), last_o(0)
+    : Continuation(NULL),
+      cycle(0),
+      last_cc(0),
+      last_rb(0),
+      last_w(0),
+      last_r(0),
+      last_wb(0),
+      last_nrb(0),
+      last_nw(0),
+      last_nr(0),
+      last_nwb(0),
+      last_p(0),
+      last_o(0)
   {
     SET_HANDLER(&ShowStats::mainEvent);
 #ifdef ENABLE_TIME_TRACE
diff --git a/proxy/ParentSelection.h b/proxy/ParentSelection.h
index ccee7d9..cb520b8 100644
--- a/proxy/ParentSelection.h
+++ b/proxy/ParentSelection.h
@@ -114,9 +114,19 @@ class ParentRecord : public ControlBase
 {
 public:
   ParentRecord()
-    : parents(NULL), secondary_parents(NULL), num_parents(0), num_secondary_parents(0), ignore_query(false), rr_next(0),
-      go_direct(true), parent_is_proxy(true), selection_strategy(NULL), unavailable_server_retry_responses(NULL),
-      parent_retry(PARENT_RETRY_NONE), max_simple_retries(1), max_unavailable_server_retries(1)
+    : parents(NULL),
+      secondary_parents(NULL),
+      num_parents(0),
+      num_secondary_parents(0),
+      ignore_query(false),
+      rr_next(0),
+      go_direct(true),
+      parent_is_proxy(true),
+      selection_strategy(NULL),
+      unavailable_server_retry_responses(NULL),
+      parent_retry(PARENT_RETRY_NONE),
+      max_simple_retries(1),
+      max_unavailable_server_retries(1)
   {
   }
 
diff --git a/proxy/PluginVC.cc b/proxy/PluginVC.cc
index cd25d9a..a0ec05d 100644
--- a/proxy/PluginVC.cc
+++ b/proxy/PluginVC.cc
@@ -86,10 +86,27 @@
 #define PVC_TYPE ((vc_type == PLUGIN_VC_ACTIVE) ? "Active" : "Passive")
 
 PluginVC::PluginVC(PluginVCCore *core_obj)
-  : NetVConnection(), magic(PLUGIN_VC_MAGIC_ALIVE), vc_type(PLUGIN_VC_UNKNOWN), core_obj(core_obj), other_side(NULL), read_state(),
-    write_state(), need_read_process(false), need_write_process(false), closed(false), sm_lock_retry_event(NULL),
-    core_lock_retry_event(NULL), deletable(false), reentrancy_count(0), active_timeout(0), active_event(NULL), inactive_timeout(0),
-    inactive_timeout_at(0), inactive_event(NULL), plugin_tag(NULL), plugin_id(0)
+  : NetVConnection(),
+    magic(PLUGIN_VC_MAGIC_ALIVE),
+    vc_type(PLUGIN_VC_UNKNOWN),
+    core_obj(core_obj),
+    other_side(NULL),
+    read_state(),
+    write_state(),
+    need_read_process(false),
+    need_write_process(false),
+    closed(false),
+    sm_lock_retry_event(NULL),
+    core_lock_retry_event(NULL),
+    deletable(false),
+    reentrancy_count(0),
+    active_timeout(0),
+    active_event(NULL),
+    inactive_timeout(0),
+    inactive_timeout_at(0),
+    inactive_event(NULL),
+    plugin_tag(NULL),
+    plugin_id(0)
 {
   ink_assert(core_obj != NULL);
   SET_HANDLER(&PluginVC::main_handler);
diff --git a/proxy/PluginVC.h b/proxy/PluginVC.h
index cf0d4d9..a9d6aca 100644
--- a/proxy/PluginVC.h
+++ b/proxy/PluginVC.h
@@ -263,8 +263,17 @@ private:
 };
 
 inline PluginVCCore::PluginVCCore()
-  : active_vc(this), passive_vc(this), connect_to(NULL), connected(false), p_to_a_buffer(NULL), p_to_a_reader(NULL),
-    a_to_p_buffer(NULL), a_to_p_reader(NULL), passive_data(NULL), active_data(NULL), id(0)
+  : active_vc(this),
+    passive_vc(this),
+    connect_to(NULL),
+    connected(false),
+    p_to_a_buffer(NULL),
+    p_to_a_reader(NULL),
+    a_to_p_buffer(NULL),
+    a_to_p_reader(NULL),
+    passive_data(NULL),
+    active_data(NULL),
+    id(0)
 {
   memset(&active_addr_struct, 0, sizeof active_addr_struct);
   memset(&passive_addr_struct, 0, sizeof passive_addr_struct);
diff --git a/proxy/Prefetch.h b/proxy/Prefetch.h
index 7b3b00e..5eb136c 100644
--- a/proxy/Prefetch.h
+++ b/proxy/Prefetch.h
@@ -64,9 +64,21 @@ struct PrefetchConfiguration {
   TSPrefetchHook embedded_obj_hook;
 
   PrefetchConfiguration()
-    : prefetch_enabled(0), html_tags_table(0), html_attrs_table(0), local_http_server_port(0), stuffer_port(0), url_buffer_size(0),
-      url_buffer_timeout(0), keepalive_timeout(0), push_cached_objects(0), max_object_size(0), max_recursion(0), redirection(0),
-      pre_parse_hook(0), embedded_url_hook(0), embedded_obj_hook(0)
+    : prefetch_enabled(0),
+      html_tags_table(0),
+      html_attrs_table(0),
+      local_http_server_port(0),
+      stuffer_port(0),
+      url_buffer_size(0),
+      url_buffer_timeout(0),
+      keepalive_timeout(0),
+      push_cached_objects(0),
+      max_object_size(0),
+      max_recursion(0),
+      redirection(0),
+      pre_parse_hook(0),
+      embedded_url_hook(0),
+      embedded_obj_hook(0)
   {
   }
   int readConfiguration();
@@ -280,8 +292,18 @@ public:
   typedef int (PrefetchBlaster::*EventHandler)(int event, void *data);
 
   PrefetchBlaster()
-    : Continuation(), url_ent(0), transform(0), url_list(0), request(0), cache_http_info(0), buf(0), reader(0), serverVC(0),
-      n_pkts_sent(0), seq_no(0), io_block(0){};
+    : Continuation(),
+      url_ent(0),
+      transform(0),
+      url_list(0),
+      request(0),
+      cache_http_info(0),
+      buf(0),
+      reader(0),
+      serverVC(0),
+      n_pkts_sent(0),
+      seq_no(0),
+      io_block(0){};
   ~PrefetchBlaster(){};
 
   int init(PrefetchUrlEntry *entry, HTTPHdr *request, PrefetchTransform *p_trans);
diff --git a/proxy/RegressionSM.h b/proxy/RegressionSM.h
index 78208f5..75513fa 100644
--- a/proxy/RegressionSM.h
+++ b/proxy/RegressionSM.h
@@ -69,8 +69,17 @@ struct RegressionSM : public Continuation {
   void xrun(RegressionSM *parent);
 
   RegressionSM(RegressionTest *at = NULL)
-    : t(at), status(REGRESSION_TEST_INPROGRESS), pstatus(0), parent(0), nwaiting(0), nchildren(0), children(0), ichild(0),
-      parallel(false), repeat(false), pending_action(0)
+    : t(at),
+      status(REGRESSION_TEST_INPROGRESS),
+      pstatus(0),
+      parent(0),
+      nwaiting(0),
+      nchildren(0),
+      children(0),
+      ichild(0),
+      parallel(false),
+      repeat(false),
+      pending_action(0)
   {
     mutex = new_ProxyMutex();
   }
diff --git a/proxy/SocksProxy.cc b/proxy/SocksProxy.cc
index 60448ed..091c1cd 100644
--- a/proxy/SocksProxy.cc
+++ b/proxy/SocksProxy.cc
@@ -57,7 +57,15 @@ struct SocksProxy : public Continuation {
   };
 
   SocksProxy()
-    : Continuation(), clientVC(0), clientVIO(0), buf(0), timeout(0), auth_handler(0), version(0), state(SOCKS_INIT), recursion(0),
+    : Continuation(),
+      clientVC(0),
+      clientVIO(0),
+      buf(0),
+      timeout(0),
+      auth_handler(0),
+      version(0),
+      state(SOCKS_INIT),
+      recursion(0),
       pending_action(NULL)
   {
   }
diff --git a/proxy/TestProxy.cc b/proxy/TestProxy.cc
index fcc061f..a8bce9e 100644
--- a/proxy/TestProxy.cc
+++ b/proxy/TestProxy.cc
@@ -373,8 +373,18 @@ struct TestProxy : Continuation {
   }
 
   TestProxy(MIOBuffer *abuf)
-    : Continuation(new_ProxyMutex()), vc(0), remote(0), inbuf(abuf), outbuf(0), clusterOutVIO(0), inVIO(0), url(0), url_end(0),
-      amode(0), tunnel(0), cachefile(0)
+    : Continuation(new_ProxyMutex()),
+      vc(0),
+      remote(0),
+      inbuf(abuf),
+      outbuf(0),
+      clusterOutVIO(0),
+      inVIO(0),
+      url(0),
+      url_end(0),
+      amode(0),
+      tunnel(0),
+      cachefile(0)
   {
     SET_HANDLER(startEvent);
   }
diff --git a/proxy/Transform.cc b/proxy/Transform.cc
index c33e989..86dcb18 100644
--- a/proxy/Transform.cc
+++ b/proxy/Transform.cc
@@ -119,7 +119,13 @@ TransformProcessor::range_transform(ProxyMutex *mut, RangeRecord *ranges, int nu
   -------------------------------------------------------------------------*/
 
 TransformTerminus::TransformTerminus(TransformVConnection *tvc)
-  : VConnection(tvc->mutex), m_tvc(tvc), m_read_vio(), m_write_vio(), m_event_count(0), m_deletable(0), m_closed(0),
+  : VConnection(tvc->mutex),
+    m_tvc(tvc),
+    m_read_vio(),
+    m_write_vio(),
+    m_event_count(0),
+    m_deletable(0),
+    m_closed(0),
     m_called_user(0)
 {
   SET_HANDLER(&TransformTerminus::handle_event);
@@ -727,10 +733,19 @@ TransformTest::run()
 
 RangeTransform::RangeTransform(ProxyMutex *mut, RangeRecord *ranges, int num_fields, HTTPHdr *transform_resp,
                                const char *content_type, int content_type_len, int64_t content_length)
-  : INKVConnInternal(NULL, reinterpret_cast<TSMutex>(mut)), m_output_buf(NULL), m_output_reader(NULL),
-    m_transform_resp(transform_resp), m_output_vio(NULL), m_range_content_length(0), m_num_range_fields(num_fields),
-    m_current_range(0), m_content_type(content_type), m_content_type_len(content_type_len), m_ranges(ranges),
-    m_output_cl(content_length), m_done(0)
+  : INKVConnInternal(NULL, reinterpret_cast<TSMutex>(mut)),
+    m_output_buf(NULL),
+    m_output_reader(NULL),
+    m_transform_resp(transform_resp),
+    m_output_vio(NULL),
+    m_range_content_length(0),
+    m_num_range_fields(num_fields),
+    m_current_range(0),
+    m_content_type(content_type),
+    m_content_type_len(content_type_len),
+    m_ranges(ranges),
+    m_output_cl(content_length),
+    m_done(0)
 {
   SET_HANDLER(&RangeTransform::handle_event);
 
diff --git a/proxy/congest/Congestion.cc b/proxy/congest/Congestion.cc
index 3aba97f..a40f6a0 100644
--- a/proxy/congest/Congestion.cc
+++ b/proxy/congest/Congestion.cc
@@ -534,8 +534,15 @@ FailHistory::regist_event(long t, int n)
 // CongestionEntry Implementation
 //----------------------------------------------------------
 CongestionEntry::CongestionEntry(const char *hostname, sockaddr const *ip, CongestionControlRecord *rule, uint64_t key)
-  : m_key(key), m_last_congested(0), m_congested(0), m_stat_congested_conn_failures(0), m_M_congested(0), m_last_M_congested(0),
-    m_num_connections(0), m_stat_congested_max_conn(0), m_ref_count(1)
+  : m_key(key),
+    m_last_congested(0),
+    m_congested(0),
+    m_stat_congested_conn_failures(0),
+    m_M_congested(0),
+    m_last_M_congested(0),
+    m_num_connections(0),
+    m_stat_congested_max_conn(0),
+    m_ref_count(1)
 {
   memset(&m_ip, 0, sizeof(m_ip));
   if (ip != NULL) {
diff --git a/proxy/congest/Congestion.h b/proxy/congest/Congestion.h
index f6df309..5bff72e 100644
--- a/proxy/congest/Congestion.h
+++ b/proxy/congest/Congestion.h
@@ -126,9 +126,24 @@ inline CongestionControlRule::~CongestionControlRule()
 }
 
 inline CongestionControlRecord::CongestionControlRecord()
-  : rank(0), prefix(NULL), prefix_len(0), port(0), congestion_scheme(PER_IP), error_page(NULL), max_connection_failures(5),
-    fail_window(120), proxy_retry_interval(10), client_wait_interval(300), wait_interval_alpha(30), live_os_conn_timeout(60),
-    live_os_conn_retries(2), dead_os_conn_timeout(15), dead_os_conn_retries(1), max_connection(-1), pRecord(NULL), ref_count(0)
+  : rank(0),
+    prefix(NULL),
+    prefix_len(0),
+    port(0),
+    congestion_scheme(PER_IP),
+    error_page(NULL),
+    max_connection_failures(5),
+    fail_window(120),
+    proxy_retry_interval(10),
+    client_wait_interval(300),
+    wait_interval_alpha(30),
+    live_os_conn_timeout(60),
+    live_os_conn_retries(2),
+    dead_os_conn_timeout(15),
+    dead_os_conn_retries(1),
+    max_connection(-1),
+    pRecord(NULL),
+    ref_count(0)
 {
 }
 
@@ -387,8 +402,17 @@ CongestionEntry::clearFailHistory()
 }
 
 inline CongestionEntry::CongestionEntry()
-  : m_key(0), m_hostname(NULL), pRecord(NULL), m_last_congested(0), m_congested(0), m_stat_congested_conn_failures(0),
-    m_M_congested(0), m_last_M_congested(0), m_num_connections(0), m_stat_congested_max_conn(0), m_ref_count(1)
+  : m_key(0),
+    m_hostname(NULL),
+    pRecord(NULL),
+    m_last_congested(0),
+    m_congested(0),
+    m_stat_congested_conn_failures(0),
+    m_M_congested(0),
+    m_last_M_congested(0),
+    m_num_connections(0),
+    m_stat_congested_max_conn(0),
+    m_ref_count(1)
 {
   memset(&m_ip, 0, sizeof(m_ip));
   m_hist_lock = new_ProxyMutex();
diff --git a/proxy/congest/CongestionTest.cc b/proxy/congest/CongestionTest.cc
index fc83948..5c530ef 100644
--- a/proxy/congest/CongestionTest.cc
+++ b/proxy/congest/CongestionTest.cc
@@ -195,8 +195,13 @@ struct CCFailHistoryTestCont : public Continuation {
   }
 
   CCFailHistoryTestCont(Ptr<ProxyMutex> _mutex, RegressionTest *_test)
-    : Continuation(_mutex), test_mode(SIMPLE_TEST), final_status(REGRESSION_TEST_PASSED), complete(false), test(_test),
-      failEvents(NULL), pending_action(NULL)
+    : Continuation(_mutex),
+      test_mode(SIMPLE_TEST),
+      final_status(REGRESSION_TEST_PASSED),
+      complete(false),
+      test(_test),
+      failEvents(NULL),
+      pending_action(NULL)
   {
     SET_HANDLER(&CCFailHistoryTestCont::mainEvent);
     rule = new CongestionControlRecord;
diff --git a/proxy/hdrs/HTTP.cc b/proxy/hdrs/HTTP.cc
index 526362b..1b97ca0 100644
--- a/proxy/hdrs/HTTP.cc
+++ b/proxy/hdrs/HTTP.cc
@@ -1779,8 +1779,18 @@ ClassAllocator<HTTPCacheAlt> httpCacheAltAllocator("httpCacheAltAllocator");
 /*-------------------------------------------------------------------------
   -------------------------------------------------------------------------*/
 HTTPCacheAlt::HTTPCacheAlt()
-  : m_magic(CACHE_ALT_MAGIC_ALIVE), m_writeable(1), m_unmarshal_len(-1), m_id(-1), m_rid(-1), m_request_hdr(), m_response_hdr(),
-    m_request_sent_time(0), m_response_received_time(0), m_frag_offset_count(0), m_frag_offsets(0), m_ext_buffer(NULL)
+  : m_magic(CACHE_ALT_MAGIC_ALIVE),
+    m_writeable(1),
+    m_unmarshal_len(-1),
+    m_id(-1),
+    m_rid(-1),
+    m_request_hdr(),
+    m_response_hdr(),
+    m_request_sent_time(0),
+    m_response_received_time(0),
+    m_frag_offset_count(0),
+    m_frag_offsets(0),
+    m_ext_buffer(NULL)
 {
   m_object_key[0] = 0;
   m_object_key[1] = 0;
diff --git a/proxy/hdrs/HdrUtils.h b/proxy/hdrs/HdrUtils.h
index 7deeaf7..b588c43 100644
--- a/proxy/hdrs/HdrUtils.h
+++ b/proxy/hdrs/HdrUtils.h
@@ -44,8 +44,16 @@ public:
   // MIME standard separator ',' is used as the default value
   // Set-cookie/Cookie uses ';'
   HdrCsvIter(const char s = ',')
-    : m_value_start(NULL), m_value_len(0), m_bytes_consumed(0), m_follow_dups(false), m_csv_start(NULL), m_csv_len(0),
-      m_csv_end(NULL), m_csv_index(0), m_cur_field(NULL), m_separator(s)
+    : m_value_start(NULL),
+      m_value_len(0),
+      m_bytes_consumed(0),
+      m_follow_dups(false),
+      m_csv_start(NULL),
+      m_csv_len(0),
+      m_csv_end(NULL),
+      m_csv_index(0),
+      m_cur_field(NULL),
+      m_separator(s)
   {
   }
   const char *get_first(const MIMEField *m, int *len, bool follow_dups = true);
diff --git a/proxy/http/Http1ClientSession.cc b/proxy/http/Http1ClientSession.cc
index ef0527a..508b593 100644
--- a/proxy/http/Http1ClientSession.cc
+++ b/proxy/http/Http1ClientSession.cc
@@ -62,9 +62,20 @@ ink_mutex debug_cs_list_mutex;
 ClassAllocator<Http1ClientSession> http1ClientSessionAllocator("http1ClientSessionAllocator");
 
 Http1ClientSession::Http1ClientSession()
-  : con_id(0), client_vc(NULL), magic(HTTP_CS_MAGIC_DEAD), transact_count(0), tcp_init_cwnd_set(false), half_close(false),
-    conn_decrease(false), read_buffer(NULL), read_state(HCS_INIT), ka_vio(NULL), slave_ka_vio(NULL), outbound_port(0),
-    f_outbound_transparent(false), m_active(false)
+  : con_id(0),
+    client_vc(NULL),
+    magic(HTTP_CS_MAGIC_DEAD),
+    transact_count(0),
+    tcp_init_cwnd_set(false),
+    half_close(false),
+    conn_decrease(false),
+    read_buffer(NULL),
+    read_state(HCS_INIT),
+    ka_vio(NULL),
+    slave_ka_vio(NULL),
+    outbound_port(0),
+    f_outbound_transparent(false),
+    m_active(false)
 {
 }
 
diff --git a/proxy/http/HttpCacheSM.cc b/proxy/http/HttpCacheSM.cc
index f471eaa..5fe5da6 100644
--- a/proxy/http/HttpCacheSM.cc
+++ b/proxy/http/HttpCacheSM.cc
@@ -61,10 +61,26 @@ HttpCacheAction::cancel(Continuation *c)
 }
 
 HttpCacheSM::HttpCacheSM()
-  : Continuation(NULL), cache_read_vc(NULL), cache_write_vc(NULL), read_locked(false), write_locked(false),
-    readwhilewrite_inprogress(false), master_sm(NULL), pending_action(NULL), captive_action(), open_read_cb(false),
-    open_write_cb(false), open_read_tries(0), read_request_hdr(NULL), read_config(NULL), read_pin_in_cache(0), retry_write(true),
-    open_write_tries(0), lookup_url(NULL), lookup_max_recursive(0), current_lookup_level(0)
+  : Continuation(NULL),
+    cache_read_vc(NULL),
+    cache_write_vc(NULL),
+    read_locked(false),
+    write_locked(false),
+    readwhilewrite_inprogress(false),
+    master_sm(NULL),
+    pending_action(NULL),
+    captive_action(),
+    open_read_cb(false),
+    open_write_cb(false),
+    open_read_tries(0),
+    read_request_hdr(NULL),
+    read_config(NULL),
+    read_pin_in_cache(0),
+    retry_write(true),
+    open_write_tries(0),
+    lookup_url(NULL),
+    lookup_max_recursive(0),
+    current_lookup_level(0)
 {
 }
 
diff --git a/proxy/http/HttpConfig.h b/proxy/http/HttpConfig.h
index 3cd75f3..d2fbbad 100644
--- a/proxy/http/HttpConfig.h
+++ b/proxy/http/HttpConfig.h
@@ -360,37 +360,110 @@ struct HttpConfigPortRange {
 // to be overridable per transaction more easily.
 struct OverridableHttpConfigParams {
   OverridableHttpConfigParams()
-    : maintain_pristine_host_hdr(1), chunking_enabled(1), negative_caching_enabled(0), negative_revalidating_enabled(0),
-      cache_when_to_revalidate(0), keep_alive_enabled_in(1), keep_alive_enabled_out(1), keep_alive_post_out(1),
-      server_session_sharing_match(TS_SERVER_SESSION_SHARING_MATCH_BOTH), auth_server_session_private(1),
-      fwd_proxy_auth_to_parent(0), uncacheable_requests_bypass_parent(1), insert_age_in_response(1), anonymize_remove_from(0),
-      anonymize_remove_referer(0), anonymize_remove_user_agent(0), anonymize_remove_cookie(0), anonymize_remove_client_ip(0),
-      anonymize_insert_client_ip(1), proxy_response_server_enabled(1), proxy_response_hsts_max_age(-1),
-      proxy_response_hsts_include_subdomains(0), insert_squid_x_forwarded_for(1), send_http11_requests(1), cache_http(1),
-      cache_cluster_cache_local(0), cache_ignore_client_no_cache(1), cache_ignore_client_cc_max_age(0),
-      cache_ims_on_client_no_cache(1), cache_ignore_server_no_cache(0), cache_responses_to_cookies(1), cache_ignore_auth(0),
-      cache_urls_that_look_dynamic(1), cache_required_headers(2), cache_range_lookup(1), cache_range_write(0),
-      insert_request_via_string(1), insert_response_via_string(0), doc_in_cache_skip_dns(1), flow_control_enabled(0),
-      accept_encoding_filter_enabled(0), normalize_ae_gzip(0), negative_caching_lifetime(1800),
-      negative_revalidating_lifetime(1800), sock_recv_buffer_size_out(0), sock_send_buffer_size_out(0), sock_option_flag_out(0),
-      sock_packet_mark_out(0), sock_packet_tos_out(0), server_tcp_init_cwnd(0), request_hdr_max_size(131072),
-      response_hdr_max_size(131072), post_check_content_length_enabled(1), cache_heuristic_min_lifetime(3600),
-      cache_heuristic_max_lifetime(86400), cache_guaranteed_min_lifetime(0), cache_guaranteed_max_lifetime(31536000),
-      cache_max_stale_age(604800), keep_alive_no_activity_timeout_in(115), keep_alive_no_activity_timeout_out(120),
-      transaction_no_activity_timeout_in(30), transaction_no_activity_timeout_out(30), transaction_active_timeout_out(0),
-      websocket_active_timeout(3600), websocket_inactive_timeout(600), origin_max_connections(0), origin_max_connections_queue(0),
-      attach_server_session_to_client(0), connect_attempts_max_retries(0), connect_attempts_max_retries_dead_server(3),
-      connect_attempts_rr_retries(3), connect_attempts_timeout(30), post_connect_attempts_timeout(1800), parent_connect_attempts(4),
-      down_server_timeout(300), client_abort_threshold(10), freshness_fuzz_time(240), freshness_fuzz_min_time(0),
-      max_cache_open_read_retries(-1), cache_open_read_retry_time(10), cache_generation_number(-1), max_cache_open_write_retries(1),
-      background_fill_active_timeout(60), http_chunking_size(4096), flow_high_water_mark(0), flow_low_water_mark(0),
-      default_buffer_size_index(8), default_buffer_water_mark(32768), slow_log_threshold(0),
+    : maintain_pristine_host_hdr(1),
+      chunking_enabled(1),
+      negative_caching_enabled(0),
+      negative_revalidating_enabled(0),
+      cache_when_to_revalidate(0),
+      keep_alive_enabled_in(1),
+      keep_alive_enabled_out(1),
+      keep_alive_post_out(1),
+      server_session_sharing_match(TS_SERVER_SESSION_SHARING_MATCH_BOTH),
+      auth_server_session_private(1),
+      fwd_proxy_auth_to_parent(0),
+      uncacheable_requests_bypass_parent(1),
+      insert_age_in_response(1),
+      anonymize_remove_from(0),
+      anonymize_remove_referer(0),
+      anonymize_remove_user_agent(0),
+      anonymize_remove_cookie(0),
+      anonymize_remove_client_ip(0),
+      anonymize_insert_client_ip(1),
+      proxy_response_server_enabled(1),
+      proxy_response_hsts_max_age(-1),
+      proxy_response_hsts_include_subdomains(0),
+      insert_squid_x_forwarded_for(1),
+      send_http11_requests(1),
+      cache_http(1),
+      cache_cluster_cache_local(0),
+      cache_ignore_client_no_cache(1),
+      cache_ignore_client_cc_max_age(0),
+      cache_ims_on_client_no_cache(1),
+      cache_ignore_server_no_cache(0),
+      cache_responses_to_cookies(1),
+      cache_ignore_auth(0),
+      cache_urls_that_look_dynamic(1),
+      cache_required_headers(2),
+      cache_range_lookup(1),
+      cache_range_write(0),
+      insert_request_via_string(1),
+      insert_response_via_string(0),
+      doc_in_cache_skip_dns(1),
+      flow_control_enabled(0),
+      accept_encoding_filter_enabled(0),
+      normalize_ae_gzip(0),
+      negative_caching_lifetime(1800),
+      negative_revalidating_lifetime(1800),
+      sock_recv_buffer_size_out(0),
+      sock_send_buffer_size_out(0),
+      sock_option_flag_out(0),
+      sock_packet_mark_out(0),
+      sock_packet_tos_out(0),
+      server_tcp_init_cwnd(0),
+      request_hdr_max_size(131072),
+      response_hdr_max_size(131072),
+      post_check_content_length_enabled(1),
+      cache_heuristic_min_lifetime(3600),
+      cache_heuristic_max_lifetime(86400),
+      cache_guaranteed_min_lifetime(0),
+      cache_guaranteed_max_lifetime(31536000),
+      cache_max_stale_age(604800),
+      keep_alive_no_activity_timeout_in(115),
+      keep_alive_no_activity_timeout_out(120),
+      transaction_no_activity_timeout_in(30),
+      transaction_no_activity_timeout_out(30),
+      transaction_active_timeout_out(0),
+      websocket_active_timeout(3600),
+      websocket_inactive_timeout(600),
+      origin_max_connections(0),
+      origin_max_connections_queue(0),
+      attach_server_session_to_client(0),
+      connect_attempts_max_retries(0),
+      connect_attempts_max_retries_dead_server(3),
+      connect_attempts_rr_retries(3),
+      connect_attempts_timeout(30),
+      post_connect_attempts_timeout(1800),
+      parent_connect_attempts(4),
+      down_server_timeout(300),
+      client_abort_threshold(10),
+      freshness_fuzz_time(240),
+      freshness_fuzz_min_time(0),
+      max_cache_open_read_retries(-1),
+      cache_open_read_retry_time(10),
+      cache_generation_number(-1),
+      max_cache_open_write_retries(1),
+      background_fill_active_timeout(60),
+      http_chunking_size(4096),
+      flow_high_water_mark(0),
+      flow_low_water_mark(0),
+      default_buffer_size_index(8),
+      default_buffer_water_mark(32768),
+      slow_log_threshold(0),
 
       // Strings / floats must come last
-      body_factory_template_base(NULL), body_factory_template_base_len(0), proxy_response_server_string(NULL),
-      proxy_response_server_string_len(0), global_user_agent_header(NULL), global_user_agent_header_size(0),
-      cache_heuristic_lm_factor(0.10), freshness_fuzz_prob(0.005), background_fill_threshold(0.5), cache_open_write_fail_action(0),
-      redirection_enabled(0), redirect_use_orig_cache_key(0), number_of_redirections(1)
+      body_factory_template_base(NULL),
+      body_factory_template_base_len(0),
+      proxy_response_server_string(NULL),
+      proxy_response_server_string_len(0),
+      global_user_agent_header(NULL),
+      global_user_agent_header_size(0),
+      cache_heuristic_lm_factor(0.10),
+      freshness_fuzz_prob(0.005),
+      background_fill_threshold(0.5),
+      cache_open_write_fail_action(0),
+      redirection_enabled(0),
+      redirect_use_orig_cache_key(0),
+      number_of_redirections(1)
   {
   }
 
@@ -851,20 +924,62 @@ extern volatile int32_t icp_dynamic_enabled;
 /////////////////////////////////////////////////////////////
 /////////////////////////////////////////////////////////////
 inline HttpConfigParams::HttpConfigParams()
-  : proxy_hostname(NULL), proxy_hostname_len(0), server_max_connections(0), origin_min_keep_alive_connections(0),
-    max_websocket_connections(-1), disable_ssl_parenting(0), enable_url_expandomatic(0), no_dns_forward_to_parent(0),
-    no_origin_server_dns(0), use_client_target_addr(0), use_client_source_port(0), proxy_request_via_string(NULL),
-    proxy_request_via_string_len(0), proxy_response_via_string(NULL), proxy_response_via_string_len(0), url_expansions_string(NULL),
-    url_expansions(NULL), num_url_expansions(0), session_auth_cache_keep_alive_enabled(1), transaction_active_timeout_in(900),
-    accept_no_activity_timeout(120), per_parent_connect_attempts(2), parent_connect_timeout(30), anonymize_other_header_list(NULL),
-    enable_http_stats(1), icp_enabled(0), stale_icp_enabled(0), cache_vary_default_text(NULL), cache_vary_default_images(NULL),
-    cache_vary_default_other(NULL), cache_enable_default_vary_headers(0), cache_post_method(0), connect_ports_string(NULL),
-    connect_ports(NULL), push_method_enabled(0), referer_filter_enabled(0), referer_format_redirect(0), strict_uri_parsing(0),
-    reverse_proxy_enabled(0), url_remap_required(1), record_cop_page(0), errors_log_error_pages(1), enable_http_info(0),
-    cluster_time_delta(0), redirection_host_no_port(1), post_copy_size(2048), ignore_accept_mismatch(0),
-    ignore_accept_language_mismatch(0), ignore_accept_encoding_mismatch(0), ignore_accept_charset_mismatch(0),
-    send_100_continue_response(0), disallow_post_100_continue(0), parser_allow_non_http(1), max_post_size(0),
-    server_session_sharing_pool(TS_SERVER_SESSION_SHARING_POOL_THREAD), synthetic_port(0)
+  : proxy_hostname(NULL),
+    proxy_hostname_len(0),
+    server_max_connections(0),
+    origin_min_keep_alive_connections(0),
+    max_websocket_connections(-1),
+    disable_ssl_parenting(0),
+    enable_url_expandomatic(0),
+    no_dns_forward_to_parent(0),
+    no_origin_server_dns(0),
+    use_client_target_addr(0),
+    use_client_source_port(0),
+    proxy_request_via_string(NULL),
+    proxy_request_via_string_len(0),
+    proxy_response_via_string(NULL),
+    proxy_response_via_string_len(0),
+    url_expansions_string(NULL),
+    url_expansions(NULL),
+    num_url_expansions(0),
+    session_auth_cache_keep_alive_enabled(1),
+    transaction_active_timeout_in(900),
+    accept_no_activity_timeout(120),
+    per_parent_connect_attempts(2),
+    parent_connect_timeout(30),
+    anonymize_other_header_list(NULL),
+    enable_http_stats(1),
+    icp_enabled(0),
+    stale_icp_enabled(0),
+    cache_vary_default_text(NULL),
+    cache_vary_default_images(NULL),
+    cache_vary_default_other(NULL),
+    cache_enable_default_vary_headers(0),
+    cache_post_method(0),
+    connect_ports_string(NULL),
+    connect_ports(NULL),
+    push_method_enabled(0),
+    referer_filter_enabled(0),
+    referer_format_redirect(0),
+    strict_uri_parsing(0),
+    reverse_proxy_enabled(0),
+    url_remap_required(1),
+    record_cop_page(0),
+    errors_log_error_pages(1),
+    enable_http_info(0),
+    cluster_time_delta(0),
+    redirection_host_no_port(1),
+    post_copy_size(2048),
+    ignore_accept_mismatch(0),
+    ignore_accept_language_mismatch(0),
+    ignore_accept_encoding_mismatch(0),
+    ignore_accept_charset_mismatch(0),
+    send_100_continue_response(0),
+    disallow_post_100_continue(0),
+    parser_allow_non_http(1),
+    max_post_size(0),
+    server_session_sharing_pool(TS_SERVER_SESSION_SHARING_POOL_THREAD),
+    synthetic_port(0)
 {
 }
 
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index 9221aa8..66c684a 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -259,22 +259,69 @@ HttpVCTable::cleanup_all()
 static int next_sm_id = 0;
 
 HttpSM::HttpSM()
-  : Continuation(NULL), sm_id(-1), magic(HTTP_SM_MAGIC_DEAD),
+  : Continuation(NULL),
+    sm_id(-1),
+    magic(HTTP_SM_MAGIC_DEAD),
     // YTS Team, yamsat Plugin
-    enable_redirection(false), redirect_url(NULL), redirect_url_len(0), redirection_tries(0), transfered_bytes(0),
-    post_failed(false), debug_on(false), plugin_tunnel_type(HTTP_NO_PLUGIN_TUNNEL), plugin_tunnel(NULL), reentrancy_count(0),
-    history_pos(0), tunnel(), ua_entry(NULL), ua_session(NULL), background_fill(BACKGROUND_FILL_NONE), ua_raw_buffer_reader(NULL),
-    server_entry(NULL), server_session(NULL), will_be_private_ss(false), shared_session_retries(0), server_buffer_reader(NULL),
-    transform_info(), post_transform_info(), has_active_plugin_agents(false), second_cache_sm(NULL), default_handler(NULL),
-    pending_action(NULL), historical_action(NULL), last_action(HttpTransact::SM_ACTION_UNDEFINED),
+    enable_redirection(false),
+    redirect_url(NULL),
+    redirect_url_len(0),
+    redirection_tries(0),
+    transfered_bytes(0),
+    post_failed(false),
+    debug_on(false),
+    plugin_tunnel_type(HTTP_NO_PLUGIN_TUNNEL),
+    plugin_tunnel(NULL),
+    reentrancy_count(0),
+    history_pos(0),
+    tunnel(),
+    ua_entry(NULL),
+    ua_session(NULL),
+    background_fill(BACKGROUND_FILL_NONE),
+    ua_raw_buffer_reader(NULL),
+    server_entry(NULL),
+    server_session(NULL),
+    will_be_private_ss(false),
+    shared_session_retries(0),
+    server_buffer_reader(NULL),
+    transform_info(),
+    post_transform_info(),
+    has_active_plugin_agents(false),
+    second_cache_sm(NULL),
+    default_handler(NULL),
+    pending_action(NULL),
+    historical_action(NULL),
+    last_action(HttpTransact::SM_ACTION_UNDEFINED),
     // TODO:  Now that bodies can be empty, should the body counters be set to -1 ? TS-2213
-    client_request_hdr_bytes(0), client_request_body_bytes(0), server_request_hdr_bytes(0), server_request_body_bytes(0),
-    server_response_hdr_bytes(0), server_response_body_bytes(0), client_response_hdr_bytes(0), client_response_body_bytes(0),
-    cache_response_hdr_bytes(0), cache_response_body_bytes(0), pushed_response_hdr_bytes(0), pushed_response_body_bytes(0),
-    client_tcp_reused(false), client_ssl_reused(false), client_connection_is_ssl(false), client_sec_protocol("-"),
-    client_cipher_suite("-"), server_transact_count(0), server_connection_is_ssl(false), plugin_tag(0), plugin_id(0),
-    hooks_set(false), cur_hook_id(TS_HTTP_LAST_HOOK), cur_hook(NULL), cur_hooks(0), callout_state(HTTP_API_NO_CALLOUT),
-    terminate_sm(false), kill_this_async_done(false), parse_range_done(false)
+    client_request_hdr_bytes(0),
+    client_request_body_bytes(0),
+    server_request_hdr_bytes(0),
+    server_request_body_bytes(0),
+    server_response_hdr_bytes(0),
+    server_response_body_bytes(0),
+    client_response_hdr_bytes(0),
+    client_response_body_bytes(0),
+    cache_response_hdr_bytes(0),
+    cache_response_body_bytes(0),
+    pushed_response_hdr_bytes(0),
+    pushed_response_body_bytes(0),
+    client_tcp_reused(false),
+    client_ssl_reused(false),
+    client_connection_is_ssl(false),
+    client_sec_protocol("-"),
+    client_cipher_suite("-"),
+    server_transact_count(0),
+    server_connection_is_ssl(false),
+    plugin_tag(0),
+    plugin_id(0),
+    hooks_set(false),
+    cur_hook_id(TS_HTTP_LAST_HOOK),
+    cur_hook(NULL),
+    cur_hooks(0),
+    callout_state(HTTP_API_NO_CALLOUT),
+    terminate_sm(false),
+    kill_this_async_done(false),
+    parse_range_done(false)
 {
   memset(&history, 0, sizeof(history));
   memset(&vc_table, 0, sizeof(vc_table));
diff --git a/proxy/http/HttpServerSession.h b/proxy/http/HttpServerSession.h
index 8f57618..129c61c 100644
--- a/proxy/http/HttpServerSession.h
+++ b/proxy/http/HttpServerSession.h
@@ -69,10 +69,22 @@ class HttpServerSession : public VConnection
 {
 public:
   HttpServerSession()
-    : VConnection(NULL), hostname_hash(), con_id(0), transact_count(0), state(HSS_INIT), to_parent_proxy(false),
-      server_trans_stat(0), private_session(false), sharing_match(TS_SERVER_SESSION_SHARING_MATCH_BOTH),
-      sharing_pool(TS_SERVER_SESSION_SHARING_POOL_GLOBAL), enable_origin_connection_limiting(false), connection_count(NULL),
-      read_buffer(NULL), server_vc(NULL), magic(HTTP_SS_MAGIC_DEAD), buf_reader(NULL)
+    : VConnection(NULL),
+      hostname_hash(),
+      con_id(0),
+      transact_count(0),
+      state(HSS_INIT),
+      to_parent_proxy(false),
+      server_trans_stat(0),
+      private_session(false),
+      sharing_match(TS_SERVER_SESSION_SHARING_MATCH_BOTH),
+      sharing_pool(TS_SERVER_SESSION_SHARING_POOL_GLOBAL),
+      enable_origin_connection_limiting(false),
+      connection_count(NULL),
+      read_buffer(NULL),
+      server_vc(NULL),
+      magic(HTTP_SS_MAGIC_DEAD),
+      buf_reader(NULL)
   {
     ink_zero(server_ip);
   }
diff --git a/proxy/http/HttpTransact.h b/proxy/http/HttpTransact.h
index 831046b..4fddf58 100644
--- a/proxy/http/HttpTransact.h
+++ b/proxy/http/HttpTransact.h
@@ -236,7 +236,11 @@ struct HttpApiInfo {
   bool retry_intercept_failures;
 
   HttpApiInfo()
-    : parent_proxy_name(NULL), parent_proxy_port(-1), cache_untransformed(false), cache_transformed(true), logging_enabled(true),
+    : parent_proxy_name(NULL),
+      parent_proxy_port(-1),
+      cache_untransformed(false),
+      cache_transformed(true),
+      logging_enabled(true),
       retry_intercept_failures(false)
   {
   }
@@ -577,8 +581,12 @@ public:
     bool does_server_permit_storing;
 
     _CacheDirectives()
-      : does_client_permit_lookup(true), does_client_permit_storing(true), does_client_permit_dns_storing(true),
-        does_config_permit_lookup(true), does_config_permit_storing(true), does_server_permit_lookup(true),
+      : does_client_permit_lookup(true),
+        does_client_permit_storing(true),
+        does_client_permit_dns_storing(true),
+        does_config_permit_lookup(true),
+        does_config_permit_storing(true),
+        does_server_permit_lookup(true),
         does_server_permit_storing(true)
     {
     }
@@ -607,10 +615,24 @@ public:
     SquidHitMissCode hit_miss_code;
 
     _CacheLookupInfo()
-      : action(CACHE_DO_UNDEFINED), transform_action(CACHE_DO_UNDEFINED), write_status(NO_CACHE_WRITE),
-        transform_write_status(NO_CACHE_WRITE), lookup_url(NULL), lookup_url_storage(), original_url(), object_read(NULL),
-        second_object_read(NULL), object_store(), transform_store(), config(), directives(), open_read_retries(0),
-        open_write_retries(0), write_lock_state(CACHE_WL_INIT), lookup_count(0), hit_miss_code(SQUID_MISS_NONE)
+      : action(CACHE_DO_UNDEFINED),
+        transform_action(CACHE_DO_UNDEFINED),
+        write_status(NO_CACHE_WRITE),
+        transform_write_status(NO_CACHE_WRITE),
+        lookup_url(NULL),
+        lookup_url_storage(),
+        original_url(),
+        object_read(NULL),
+        second_object_read(NULL),
+        object_store(),
+        transform_store(),
+        config(),
+        directives(),
+        open_read_retries(0),
+        open_write_retries(0),
+        write_lock_state(CACHE_WL_INIT),
+        lookup_count(0),
+        hit_miss_code(SQUID_MISS_NONE)
     {
     }
   } CacheLookupInfo;
@@ -671,9 +693,18 @@ public:
     }
 
     ConnectionAttributes()
-      : http_version(), keep_alive(HTTP_KEEPALIVE_UNDEFINED), receive_chunked_response(false), pipeline_possible(false),
-        proxy_connect_hdr(false), connect_result(0), name(NULL), transfer_encoding(NO_TRANSFER_ENCODING), state(STATE_UNDEFINED),
-        abort(ABORT_UNDEFINED), port_attribute(HttpProxyPort::TRANSPORT_DEFAULT), is_transparent(false)
+      : http_version(),
+        keep_alive(HTTP_KEEPALIVE_UNDEFINED),
+        receive_chunked_response(false),
+        pipeline_possible(false),
+        proxy_connect_hdr(false),
+        connect_result(0),
+        name(NULL),
+        transfer_encoding(NO_TRANSFER_ENCODING),
+        state(STATE_UNDEFINED),
+        abort(ABORT_UNDEFINED),
+        port_attribute(HttpProxyPort::TRANSPORT_DEFAULT),
+        is_transparent(false)
     {
       memset(&src_addr, 0, sizeof(src_addr));
       memset(&dst_addr, 0, sizeof(dst_addr));
@@ -692,8 +723,15 @@ public:
     ParentOriginRetry_t retry_type;
 
     _CurrentInfo()
-      : mode(UNDEFINED_MODE), request_to(UNDEFINED_LOOKUP), server(NULL), now(0), state(STATE_UNDEFINED), attempts(1),
-        simple_retry_attempts(0), unavailable_server_retry_attempts(0), retry_type(PARENT_ORIGIN_UNDEFINED_RETRY){};
+      : mode(UNDEFINED_MODE),
+        request_to(UNDEFINED_LOOKUP),
+        server(NULL),
+        now(0),
+        state(STATE_UNDEFINED),
+        attempts(1),
+        simple_retry_attempts(0),
+        unavailable_server_retry_attempts(0),
+        retry_type(PARENT_ORIGIN_UNDEFINED_RETRY){};
   } CurrentInfo;
 
   typedef struct _DNSLookupInfo {
@@ -730,8 +768,14 @@ public:
     bool lookup_validated;
 
     _DNSLookupInfo()
-      : attempts(0), os_addr_style(OS_ADDR_TRY_DEFAULT), lookup_success(false), lookup_name(NULL), looking_up(UNDEFINED_LOOKUP),
-        srv_lookup_success(false), srv_port(0), lookup_validated(true)
+      : attempts(0),
+        os_addr_style(OS_ADDR_TRY_DEFAULT),
+        lookup_success(false),
+        lookup_name(NULL),
+        looking_up(UNDEFINED_LOOKUP),
+        srv_lookup_success(false),
+        srv_port(0),
+        lookup_validated(true)
     {
       srv_hostname[0] = '\0';
       srv_app.allotment.application1 = 0;
@@ -756,10 +800,20 @@ public:
     bool extension_method;
 
     _HeaderInfo()
-      : client_request(), client_response(), server_request(), server_response(), transform_response(), cache_response(),
-        request_content_length(HTTP_UNDEFINED_CL), response_content_length(HTTP_UNDEFINED_CL),
-        transform_request_cl(HTTP_UNDEFINED_CL), transform_response_cl(HTTP_UNDEFINED_CL), client_req_is_server_style(false),
-        trust_response_cl(false), response_error(NO_RESPONSE_HEADER_ERROR), extension_method(false)
+      : client_request(),
+        client_response(),
+        server_request(),
+        server_response(),
+        transform_response(),
+        cache_response(),
+        request_content_length(HTTP_UNDEFINED_CL),
+        response_content_length(HTTP_UNDEFINED_CL),
+        transform_request_cl(HTTP_UNDEFINED_CL),
+        transform_response_cl(HTTP_UNDEFINED_CL),
+        client_req_is_server_style(false),
+        trust_response_cl(false),
+        response_error(NO_RESPONSE_HEADER_ERROR),
+        extension_method(false)
     {
     }
   } HeaderInfo;
@@ -950,33 +1004,98 @@ public:
 
     // Constructor
     State()
-      : m_magic(HTTP_TRANSACT_MAGIC_ALIVE), state_machine(NULL), http_config_param(NULL), force_dns(false),
-        updated_server_version(HostDBApplicationInfo::HTTP_VERSION_UNDEFINED), cache_open_write_fail_action(0),
-        is_revalidation_necessary(false), request_will_not_selfloop(false), // YTS Team, yamsat
-        source(SOURCE_NONE), pre_transform_source(SOURCE_NONE), req_flavor(REQ_FLAVOR_FWDPROXY), pending_work(NULL),
-        cdn_saved_next_action(SM_ACTION_UNDEFINED), cdn_saved_transact_return_point(NULL), cdn_remap_complete(false),
-        first_dns_lookup(true), backdoor_request(false), cop_test_page(false), parent_params(NULL),
-        cache_lookup_result(CACHE_LOOKUP_NONE), next_action(SM_ACTION_UNDEFINED), api_next_action(SM_ACTION_UNDEFINED),
-        transact_return_point(NULL), post_remap_upgrade_return_point(NULL), upgrade_token_wks(NULL), is_upgrade_request(false),
-        is_websocket(false), did_upgrade_succeed(false), origin_request_queued(false), internal_msg_buffer(NULL),
-        internal_msg_buffer_type(NULL), internal_msg_buffer_size(0), internal_msg_buffer_fast_allocator_size(-1),
-        icp_lookup_success(false), scheme(-1), next_hop_scheme(scheme), orig_scheme(scheme), method(0),
-        cause_of_death_errno(-UNKNOWN_INTERNAL_ERROR), client_request_time(UNDEFINED_TIME), request_sent_time(UNDEFINED_TIME),
-        response_received_time(UNDEFINED_TIME), plugin_set_expire_time(UNDEFINED_TIME), state_machine_id(0),
-        client_connection_enabled(true), acl_filtering_performed(false), negative_caching(false), srv_lookup(false),
-        www_auth_content(CACHE_AUTH_NONE), remap_plugin_instance(0), fp_tsremap_os_response(NULL),
-        http_return_code(HTTP_STATUS_NONE), api_txn_active_timeout_value(-1), api_txn_connect_timeout_value(-1),
-        api_txn_dns_timeout_value(-1), api_txn_no_activity_timeout_value(-1), cache_req_hdr_heap_handle(NULL),
-        cache_resp_hdr_heap_handle(NULL), api_cleanup_cache_read(false), api_server_response_no_store(false),
-        api_server_response_ignore(false), api_http_sm_shutdown(false), api_modifiable_cached_resp(false),
-        api_server_request_body_set(false), api_req_cacheable(false), api_resp_cacheable(false), api_server_addr_set(false),
-        stale_icp_lookup(false), api_update_cached_object(UPDATE_CACHED_OBJECT_NONE), api_lock_url(LOCK_URL_FIRST),
-        saved_update_next_action(SM_ACTION_UNDEFINED), saved_update_cache_action(CACHE_DO_UNDEFINED), url_map(),
-        pCongestionEntry(NULL), congest_saved_next_action(SM_ACTION_UNDEFINED), congestion_control_crat(0),
-        congestion_congested_or_failed(0), congestion_connection_opened(0), filter_mask(0), remap_redirect(NULL),
-        reverse_proxy(false), url_remap_success(false), api_skip_all_remapping(false), already_downgraded(false), pristine_url(),
-        range_setup(RANGE_NONE), num_range_fields(0), range_output_cl(0), ranges(NULL), txn_conf(NULL),
-        transparent_passthrough(false), range_in_cache(false)
+      : m_magic(HTTP_TRANSACT_MAGIC_ALIVE),
+        state_machine(NULL),
+        http_config_param(NULL),
+        force_dns(false),
+        updated_server_version(HostDBApplicationInfo::HTTP_VERSION_UNDEFINED),
+        cache_open_write_fail_action(0),
+        is_revalidation_necessary(false),
+        request_will_not_selfloop(false), // YTS Team, yamsat
+        source(SOURCE_NONE),
+        pre_transform_source(SOURCE_NONE),
+        req_flavor(REQ_FLAVOR_FWDPROXY),
+        pending_work(NULL),
+        cdn_saved_next_action(SM_ACTION_UNDEFINED),
+        cdn_saved_transact_return_point(NULL),
+        cdn_remap_complete(false),
+        first_dns_lookup(true),
+        backdoor_request(false),
+        cop_test_page(false),
+        parent_params(NULL),
+        cache_lookup_result(CACHE_LOOKUP_NONE),
+        next_action(SM_ACTION_UNDEFINED),
+        api_next_action(SM_ACTION_UNDEFINED),
+        transact_return_point(NULL),
+        post_remap_upgrade_return_point(NULL),
+        upgrade_token_wks(NULL),
+        is_upgrade_request(false),
+        is_websocket(false),
+        did_upgrade_succeed(false),
+        origin_request_queued(false),
+        internal_msg_buffer(NULL),
+        internal_msg_buffer_type(NULL),
+        internal_msg_buffer_size(0),
+        internal_msg_buffer_fast_allocator_size(-1),
+        icp_lookup_success(false),
+        scheme(-1),
+        next_hop_scheme(scheme),
+        orig_scheme(scheme),
+        method(0),
+        cause_of_death_errno(-UNKNOWN_INTERNAL_ERROR),
+        client_request_time(UNDEFINED_TIME),
+        request_sent_time(UNDEFINED_TIME),
+        response_received_time(UNDEFINED_TIME),
+        plugin_set_expire_time(UNDEFINED_TIME),
+        state_machine_id(0),
+        client_connection_enabled(true),
+        acl_filtering_performed(false),
+        negative_caching(false),
+        srv_lookup(false),
+        www_auth_content(CACHE_AUTH_NONE),
+        remap_plugin_instance(0),
+        fp_tsremap_os_response(NULL),
+        http_return_code(HTTP_STATUS_NONE),
+        api_txn_active_timeout_value(-1),
+        api_txn_connect_timeout_value(-1),
+        api_txn_dns_timeout_value(-1),
+        api_txn_no_activity_timeout_value(-1),
+        cache_req_hdr_heap_handle(NULL),
+        cache_resp_hdr_heap_handle(NULL),
+        api_cleanup_cache_read(false),
+        api_server_response_no_store(false),
+        api_server_response_ignore(false),
+        api_http_sm_shutdown(false),
+        api_modifiable_cached_resp(false),
+        api_server_request_body_set(false),
+        api_req_cacheable(false),
+        api_resp_cacheable(false),
+        api_server_addr_set(false),
+        stale_icp_lookup(false),
+        api_update_cached_object(UPDATE_CACHED_OBJECT_NONE),
+        api_lock_url(LOCK_URL_FIRST),
+        saved_update_next_action(SM_ACTION_UNDEFINED),
+        saved_update_cache_action(CACHE_DO_UNDEFINED),
+        url_map(),
+        pCongestionEntry(NULL),
+        congest_saved_next_action(SM_ACTION_UNDEFINED),
+        congestion_control_crat(0),
+        congestion_congested_or_failed(0),
+        congestion_connection_opened(0),
+        filter_mask(0),
+        remap_redirect(NULL),
+        reverse_proxy(false),
+        url_remap_success(false),
+        api_skip_all_remapping(false),
+        already_downgraded(false),
+        pristine_url(),
+        range_setup(RANGE_NONE),
+        num_range_fields(0),
+        range_output_cl(0),
+        ranges(NULL),
+        txn_conf(NULL),
+        transparent_passthrough(false),
+        range_in_cache(false)
     {
       int i;
       char *via_ptr = via_string;
diff --git a/proxy/http/HttpTransactCache.h b/proxy/http/HttpTransactCache.h
index 794e4e6..974a887 100644
--- a/proxy/http/HttpTransactCache.h
+++ b/proxy/http/HttpTransactCache.h
@@ -57,9 +57,15 @@ public:
   int unmarshal(Arena *arena, const char *buf, int length);
 
   CacheLookupHttpConfig()
-    : cache_global_user_agent_header(false), cache_enable_default_vary_headers(false), ignore_accept_mismatch(0),
-      ignore_accept_language_mismatch(0), ignore_accept_encoding_mismatch(0), ignore_accept_charset_mismatch(0),
-      cache_vary_default_text(NULL), cache_vary_default_images(NULL), cache_vary_default_other(NULL)
+    : cache_global_user_agent_header(false),
+      cache_enable_default_vary_headers(false),
+      ignore_accept_mismatch(0),
+      ignore_accept_language_mismatch(0),
+      ignore_accept_encoding_mismatch(0),
+      ignore_accept_charset_mismatch(0),
+      cache_vary_default_text(NULL),
+      cache_vary_default_images(NULL),
+      cache_vary_default_other(NULL)
   {
   }
 
diff --git a/proxy/http/HttpTunnel.cc b/proxy/http/HttpTunnel.cc
index 3b9267a..adc84ae 100644
--- a/proxy/http/HttpTunnel.cc
+++ b/proxy/http/HttpTunnel.cc
@@ -71,9 +71,22 @@ VcTypeCode(HttpTunnelType_t t)
 }
 
 ChunkedHandler::ChunkedHandler()
-  : action(ACTION_UNSET), chunked_reader(NULL), dechunked_buffer(NULL), dechunked_size(0), dechunked_reader(NULL),
-    chunked_buffer(NULL), chunked_size(0), truncation(false), skip_bytes(0), state(CHUNK_READ_CHUNK), cur_chunk_size(0),
-    bytes_left(0), last_server_event(VC_EVENT_NONE), running_sum(0), num_digits(0), max_chunk_size(DEFAULT_MAX_CHUNK_SIZE),
+  : action(ACTION_UNSET),
+    chunked_reader(NULL),
+    dechunked_buffer(NULL),
+    dechunked_size(0),
+    dechunked_reader(NULL),
+    chunked_buffer(NULL),
+    chunked_size(0),
+    truncation(false),
+    skip_bytes(0),
+    state(CHUNK_READ_CHUNK),
+    cur_chunk_size(0),
+    bytes_left(0),
+    last_server_event(VC_EVENT_NONE),
+    running_sum(0),
+    num_digits(0),
+    max_chunk_size(DEFAULT_MAX_CHUNK_SIZE),
     max_chunk_header_len(0)
 {
 }
@@ -404,10 +417,29 @@ ChunkedHandler::generate_chunked_content()
 }
 
 HttpTunnelProducer::HttpTunnelProducer()
-  : consumer_list(), self_consumer(NULL), vc(NULL), vc_handler(NULL), read_vio(NULL), read_buffer(NULL), buffer_start(NULL),
-    vc_type(HT_HTTP_SERVER), chunking_action(TCA_PASSTHRU_DECHUNKED_CONTENT), do_chunking(false), do_dechunking(false),
-    do_chunked_passthru(false), init_bytes_done(0), nbytes(0), ntodo(0), bytes_read(0), handler_state(0), last_event(0),
-    num_consumers(0), alive(false), read_success(false), flow_control_source(0), name(NULL)
+  : consumer_list(),
+    self_consumer(NULL),
+    vc(NULL),
+    vc_handler(NULL),
+    read_vio(NULL),
+    read_buffer(NULL),
+    buffer_start(NULL),
+    vc_type(HT_HTTP_SERVER),
+    chunking_action(TCA_PASSTHRU_DECHUNKED_CONTENT),
+    do_chunking(false),
+    do_dechunking(false),
+    do_chunked_passthru(false),
+    init_bytes_done(0),
+    nbytes(0),
+    ntodo(0),
+    bytes_read(0),
+    handler_state(0),
+    last_event(0),
+    num_consumers(0),
+    alive(false),
+    read_success(false),
+    flow_control_source(0),
+    name(NULL)
 {
 }
 
@@ -472,13 +504,31 @@ HttpTunnelProducer::set_throttle_src(HttpTunnelProducer *srcp)
 }
 
 HttpTunnelConsumer::HttpTunnelConsumer()
-  : link(), producer(NULL), self_producer(NULL), vc_type(HT_HTTP_CLIENT), vc(NULL), buffer_reader(NULL), vc_handler(NULL),
-    write_vio(NULL), skip_bytes(0), bytes_written(0), handler_state(0), alive(false), write_success(false), name(NULL)
+  : link(),
+    producer(NULL),
+    self_producer(NULL),
+    vc_type(HT_HTTP_CLIENT),
+    vc(NULL),
+    buffer_reader(NULL),
+    vc_handler(NULL),
+    write_vio(NULL),
+    skip_bytes(0),
+    bytes_written(0),
+    handler_state(0),
+    alive(false),
+    write_success(false),
+    name(NULL)
 {
 }
 
 HttpTunnel::HttpTunnel()
-  : Continuation(NULL), num_producers(0), num_consumers(0), sm(NULL), active(false), postbuf(NULL), reentrancy_count(0),
+  : Continuation(NULL),
+    num_producers(0),
+    num_consumers(0),
+    sm(NULL),
+    active(false),
+    postbuf(NULL),
+    reentrancy_count(0),
     call_sm(false)
 {
 }
diff --git a/proxy/http/HttpTunnel.h b/proxy/http/HttpTunnel.h
index 0feed3d..c4fce16 100644
--- a/proxy/http/HttpTunnel.h
+++ b/proxy/http/HttpTunnel.h
@@ -257,7 +257,10 @@ class PostDataBuffers
 {
 public:
   PostDataBuffers()
-    : postdata_producer_buffer(NULL), postdata_copy_buffer(NULL), postdata_producer_reader(NULL), postdata_copy_buffer_start(NULL),
+    : postdata_producer_buffer(NULL),
+      postdata_copy_buffer(NULL),
+      postdata_producer_reader(NULL),
+      postdata_copy_buffer_start(NULL),
       ua_buffer_reader(NULL)
   {
     Debug("http_redirect", "[PostDataBuffers::PostDataBuffers]");
diff --git a/proxy/http/HttpUpdateTester.cc b/proxy/http/HttpUpdateTester.cc
index 469a4dd..4374169 100644
--- a/proxy/http/HttpUpdateTester.cc
+++ b/proxy/http/HttpUpdateTester.cc
@@ -45,10 +45,12 @@ private:
 };
 
 UpTest::UpTest(FILE * /* f ATS_UNUSED */, ProxyMutex *amutex)
-  : Continuation(amutex), active_req(0)
+  : Continuation(amutex),
+    active_req(0)
 #ifdef GO_AWAY
     ,
-    total_req(0), file(f)
+    total_req(0),
+    file(f)
 #endif
 {
   SET_HANDLER(&UpTest::main_handler);
diff --git a/proxy/http/remap/RemapPluginInfo.cc b/proxy/http/remap/RemapPluginInfo.cc
index 35b6bca..0b09fec 100644
--- a/proxy/http/remap/RemapPluginInfo.cc
+++ b/proxy/http/remap/RemapPluginInfo.cc
@@ -26,8 +26,16 @@
 #include "ts/ink_memory.h"
 
 remap_plugin_info::remap_plugin_info(char *_path)
-  : next(0), path(NULL), path_size(0), dlh(NULL), fp_tsremap_init(NULL), fp_tsremap_done(NULL), fp_tsremap_new_instance(NULL),
-    fp_tsremap_delete_instance(NULL), fp_tsremap_do_remap(NULL), fp_tsremap_os_response(NULL)
+  : next(0),
+    path(NULL),
+    path_size(0),
+    dlh(NULL),
+    fp_tsremap_init(NULL),
+    fp_tsremap_done(NULL),
+    fp_tsremap_new_instance(NULL),
+    fp_tsremap_delete_instance(NULL),
+    fp_tsremap_do_remap(NULL),
+    fp_tsremap_os_response(NULL)
 {
   // coverity did not see ats_free
   // coverity[ctor_dtor_leak]
diff --git a/proxy/http/remap/UrlMapping.cc b/proxy/http/remap/UrlMapping.cc
index dd500ed..7f15961 100644
--- a/proxy/http/remap/UrlMapping.cc
+++ b/proxy/http/remap/UrlMapping.cc
@@ -29,9 +29,22 @@
  *
 **/
 url_mapping::url_mapping(int rank /* = 0 */)
-  : from_path_len(0), fromURL(), toUrl(), homePageRedirect(false), unique(false), default_redirect_url(false),
-    optional_referer(false), negative_referer(false), wildcard_from_scheme(false), tag(NULL), filter_redirect_url(NULL),
-    referer_list(0), redir_chunk_list(0), filter(NULL), _plugin_count(0), _rank(rank)
+  : from_path_len(0),
+    fromURL(),
+    toUrl(),
+    homePageRedirect(false),
+    unique(false),
+    default_redirect_url(false),
+    optional_referer(false),
+    negative_referer(false),
+    wildcard_from_scheme(false),
+    tag(NULL),
+    filter_redirect_url(NULL),
+    referer_list(0),
+    redir_chunk_list(0),
+    filter(NULL),
+    _plugin_count(0),
+    _rank(rank)
 {
   memset(_plugin_list, 0, sizeof(_plugin_list));
   memset(_instance_data, 0, sizeof(_instance_data));
diff --git a/proxy/http/remap/UrlRewrite.cc b/proxy/http/remap/UrlRewrite.cc
index a152b14..ce16b88 100644
--- a/proxy/http/remap/UrlRewrite.cc
+++ b/proxy/http/remap/UrlRewrite.cc
@@ -54,8 +54,16 @@ SetHomePageRedirectFlag(url_mapping *new_mapping, URL &new_to_url)
 // CTOR / DTOR for the UrlRewrite class.
 //
 UrlRewrite::UrlRewrite()
-  : nohost_rules(0), reverse_proxy(0), mgmt_synthetic_port(0), ts_name(NULL), http_default_redirect_url(NULL), num_rules_forward(0),
-    num_rules_reverse(0), num_rules_redirect_permanent(0), num_rules_redirect_temporary(0), num_rules_forward_with_recv_port(0),
+  : nohost_rules(0),
+    reverse_proxy(0),
+    mgmt_synthetic_port(0),
+    ts_name(NULL),
+    http_default_redirect_url(NULL),
+    num_rules_forward(0),
+    num_rules_reverse(0),
+    num_rules_redirect_permanent(0),
+    num_rules_redirect_temporary(0),
+    num_rules_forward_with_recv_port(0),
     _valid(false)
 {
   ats_scoped_str config_file_path;
diff --git a/proxy/http2/Http2ClientSession.cc b/proxy/http2/Http2ClientSession.cc
index 5930140..5bbcab4 100644
--- a/proxy/http2/Http2ClientSession.cc
+++ b/proxy/http2/Http2ClientSession.cc
@@ -59,7 +59,13 @@ send_connection_event(Continuation *cont, int event, void *edata)
 }
 
 Http2ClientSession::Http2ClientSession()
-  : con_id(0), total_write_len(0), client_vc(NULL), read_buffer(NULL), sm_reader(NULL), write_buffer(NULL), sm_writer(NULL),
+  : con_id(0),
+    total_write_len(0),
+    client_vc(NULL),
+    read_buffer(NULL),
+    sm_reader(NULL),
+    write_buffer(NULL),
+    sm_writer(NULL),
     upgrade_context()
 {
 }
diff --git a/proxy/http2/Http2ConnectionState.h b/proxy/http2/Http2ConnectionState.h
index 9d6502c..c4dc5d5 100644
--- a/proxy/http2/Http2ConnectionState.h
+++ b/proxy/http2/Http2ConnectionState.h
@@ -104,8 +104,14 @@ class Http2ConnectionState : public Continuation
 {
 public:
   Http2ConnectionState()
-    : Continuation(NULL), ua_session(NULL), client_rwnd(HTTP2_INITIAL_WINDOW_SIZE), server_rwnd(Http2::initial_window_size),
-      stream_list(), latest_streamid(0), client_streams_count(0), continued_stream_id(0)
+    : Continuation(NULL),
+      ua_session(NULL),
+      client_rwnd(HTTP2_INITIAL_WINDOW_SIZE),
+      server_rwnd(Http2::initial_window_size),
+      stream_list(),
+      latest_streamid(0),
+      client_streams_count(0),
+      continued_stream_id(0)
   {
     SET_HANDLER(&Http2ConnectionState::main_event_handler);
   }
diff --git a/proxy/http2/Http2Stream.h b/proxy/http2/Http2Stream.h
index 6c701d0..5ef7818 100644
--- a/proxy/http2/Http2Stream.h
+++ b/proxy/http2/Http2Stream.h
@@ -36,11 +36,27 @@ class Http2Stream : public ProxyClientTransaction
 public:
   typedef ProxyClientTransaction super; ///< Parent type.
   Http2Stream(Http2StreamId sid = 0, ssize_t initial_rwnd = Http2::initial_window_size)
-    : client_rwnd(initial_rwnd), server_rwnd(Http2::initial_window_size), header_blocks(NULL), header_blocks_length(0),
-      request_header_length(0), end_stream(false), response_reader(NULL), request_reader(NULL),
-      request_buffer(CLIENT_CONNECTION_FIRST_READ_BUFFER_SIZE_INDEX), _id(sid), _state(HTTP2_STREAM_STATE_IDLE),
-      trailing_header(false), body_done(false), data_length(0), closed(false), sent_delete(false), bytes_sent(0), chunked(false),
-      cross_thread_event(NULL), active_event(NULL), inactive_event(NULL)
+    : client_rwnd(initial_rwnd),
+      server_rwnd(Http2::initial_window_size),
+      header_blocks(NULL),
+      header_blocks_length(0),
+      request_header_length(0),
+      end_stream(false),
+      response_reader(NULL),
+      request_reader(NULL),
+      request_buffer(CLIENT_CONNECTION_FIRST_READ_BUFFER_SIZE_INDEX),
+      _id(sid),
+      _state(HTTP2_STREAM_STATE_IDLE),
+      trailing_header(false),
+      body_done(false),
+      data_length(0),
+      closed(false),
+      sent_delete(false),
+      bytes_sent(0),
+      chunked(false),
+      cross_thread_event(NULL),
+      active_event(NULL),
+      inactive_event(NULL)
   {
     SET_HANDLER(&Http2Stream::main_event_handler);
   }
diff --git a/proxy/logging/LogAccessHttp.cc b/proxy/logging/LogAccessHttp.cc
index 1d736cf..d6b74d2 100644
--- a/proxy/logging/LogAccessHttp.cc
+++ b/proxy/logging/LogAccessHttp.cc
@@ -49,12 +49,28 @@
   -------------------------------------------------------------------------*/
 
 LogAccessHttp::LogAccessHttp(HttpSM *sm)
-  : m_http_sm(sm), m_arena(), m_client_request(NULL), m_proxy_response(NULL), m_proxy_request(NULL), m_server_response(NULL),
-    m_cache_response(NULL), m_client_req_url_str(NULL), m_client_req_url_len(0), m_client_req_url_canon_str(NULL),
-    m_client_req_url_canon_len(0), m_client_req_unmapped_url_canon_str(NULL), m_client_req_unmapped_url_canon_len(-1),
-    m_client_req_unmapped_url_path_str(NULL), m_client_req_unmapped_url_path_len(-1), m_client_req_unmapped_url_host_str(NULL),
-    m_client_req_unmapped_url_host_len(-1), m_client_req_url_path_str(NULL), m_client_req_url_path_len(0),
-    m_proxy_resp_content_type_str(NULL), m_proxy_resp_content_type_len(0), m_cache_lookup_url_canon_str(NULL),
+  : m_http_sm(sm),
+    m_arena(),
+    m_client_request(NULL),
+    m_proxy_response(NULL),
+    m_proxy_request(NULL),
+    m_server_response(NULL),
+    m_cache_response(NULL),
+    m_client_req_url_str(NULL),
+    m_client_req_url_len(0),
+    m_client_req_url_canon_str(NULL),
+    m_client_req_url_canon_len(0),
+    m_client_req_unmapped_url_canon_str(NULL),
+    m_client_req_unmapped_url_canon_len(-1),
+    m_client_req_unmapped_url_path_str(NULL),
+    m_client_req_unmapped_url_path_len(-1),
+    m_client_req_unmapped_url_host_str(NULL),
+    m_client_req_unmapped_url_host_len(-1),
+    m_client_req_url_path_str(NULL),
+    m_client_req_url_path_len(0),
+    m_proxy_resp_content_type_str(NULL),
+    m_proxy_resp_content_type_len(0),
+    m_cache_lookup_url_canon_str(NULL),
     m_cache_lookup_url_canon_len(0)
 {
   ink_assert(m_http_sm != NULL);
diff --git a/proxy/logging/LogBuffer.cc b/proxy/logging/LogBuffer.cc
index 8af18c0..75a370b 100644
--- a/proxy/logging/LogBuffer.cc
+++ b/proxy/logging/LogBuffer.cc
@@ -155,8 +155,16 @@ LogBuffer::LogBuffer(LogObject *owner, size_t size, size_t buf_align, size_t wri
 }
 
 LogBuffer::LogBuffer(LogObject *owner, LogBufferHeader *header)
-  : m_unaligned_buffer(NULL), m_buffer((char *)header), m_size(0), m_buf_align(LB_DEFAULT_ALIGN), m_write_align(INK_MIN_ALIGN),
-    m_buffer_fast_allocator_size(-1), m_expiration_time(0), m_owner(owner), m_header(header), m_references(0)
+  : m_unaligned_buffer(NULL),
+    m_buffer((char *)header),
+    m_size(0),
+    m_buf_align(LB_DEFAULT_ALIGN),
+    m_write_align(INK_MIN_ALIGN),
+    m_buffer_fast_allocator_size(-1),
+    m_expiration_time(0),
+    m_owner(owner),
+    m_header(header),
+    m_references(0)
 {
   // This constructor does not allocate a buffer because it gets it as
   // an argument. We set m_unaligned_buffer to NULL, which means that
diff --git a/proxy/logging/LogCollationClientSM.cc b/proxy/logging/LogCollationClientSM.cc
index 34185f4..5cab601 100644
--- a/proxy/logging/LogCollationClientSM.cc
+++ b/proxy/logging/LogCollationClientSM.cc
@@ -60,10 +60,23 @@ int LogCollationClientSM::ID = 0;
 //-------------------------------------------------------------------------
 
 LogCollationClientSM::LogCollationClientSM(LogHost *log_host)
-  : Continuation(new_ProxyMutex()), m_host_vc(NULL), m_host_vio(NULL), m_auth_buffer(NULL), m_auth_reader(NULL),
-    m_send_buffer(NULL), m_send_reader(NULL), m_pending_action(NULL), m_pending_event(NULL), m_abort_vio(NULL),
-    m_abort_buffer(NULL), m_host_is_up(false), m_buffer_send_list(NULL), m_buffer_in_iocore(NULL), m_flow(LOG_COLL_FLOW_ALLOW),
-    m_log_host(log_host), m_id(ID++)
+  : Continuation(new_ProxyMutex()),
+    m_host_vc(NULL),
+    m_host_vio(NULL),
+    m_auth_buffer(NULL),
+    m_auth_reader(NULL),
+    m_send_buffer(NULL),
+    m_send_reader(NULL),
+    m_pending_action(NULL),
+    m_pending_event(NULL),
+    m_abort_vio(NULL),
+    m_abort_buffer(NULL),
+    m_host_is_up(false),
+    m_buffer_send_list(NULL),
+    m_buffer_in_iocore(NULL),
+    m_flow(LOG_COLL_FLOW_ALLOW),
+    m_log_host(log_host),
+    m_id(ID++)
 {
   Debug("log-coll", "[%d]client::constructor", m_id);
 
diff --git a/proxy/logging/LogCollationHostSM.cc b/proxy/logging/LogCollationHostSM.cc
index 75e9512..37eb989 100644
--- a/proxy/logging/LogCollationHostSM.cc
+++ b/proxy/logging/LogCollationHostSM.cc
@@ -60,9 +60,19 @@ int LogCollationHostSM::ID = 0;
 //-------------------------------------------------------------------------
 
 LogCollationHostSM::LogCollationHostSM(NetVConnection *client_vc)
-  : Continuation(new_ProxyMutex()), m_client_vc(client_vc), m_client_vio(NULL), m_client_buffer(NULL), m_client_reader(NULL),
-    m_pending_event(NULL), m_read_buffer(NULL), m_read_bytes_wanted(0), m_read_bytes_received(0),
-    m_read_buffer_fast_allocator_size(-1), m_client_ip(0), m_client_port(0), m_id(ID++)
+  : Continuation(new_ProxyMutex()),
+    m_client_vc(client_vc),
+    m_client_vio(NULL),
+    m_client_buffer(NULL),
+    m_client_reader(NULL),
+    m_pending_event(NULL),
+    m_read_buffer(NULL),
+    m_read_bytes_wanted(0),
+    m_read_bytes_received(0),
+    m_read_buffer_fast_allocator_size(-1),
+    m_client_ip(0),
+    m_client_port(0),
+    m_id(ID++)
 {
   Debug("log-coll", "[%d]host::constructor", m_id);
 
diff --git a/proxy/logging/LogConfig.cc b/proxy/logging/LogConfig.cc
index 448ffb3..7efefee 100644
--- a/proxy/logging/LogConfig.cc
+++ b/proxy/logging/LogConfig.cc
@@ -274,9 +274,19 @@ LogConfig::read_configuration_variables()
 
 // TODO: Is UINT_MAX here really correct?
 LogConfig::LogConfig()
-  : initialized(false), reconfiguration_needed(false), logging_space_exhausted(false), m_space_used(0),
-    m_partition_space_left((int64_t)UINT_MAX), m_log_collation_accept(NULL), m_dir_entry(NULL), m_pDir(NULL), m_disk_full(false),
-    m_disk_low(false), m_partition_full(false), m_partition_low(false), m_log_directory_inaccessible(false)
+  : initialized(false),
+    reconfiguration_needed(false),
+    logging_space_exhausted(false),
+    m_space_used(0),
+    m_partition_space_left((int64_t)UINT_MAX),
+    m_log_collation_accept(NULL),
+    m_dir_entry(NULL),
+    m_pDir(NULL),
+    m_disk_full(false),
+    m_disk_low(false),
+    m_partition_full(false),
+    m_partition_low(false),
+    m_log_directory_inaccessible(false)
 {
   // Setup the default values for all LogConfig public variables so that
   // a LogConfig object is valid upon return from the constructor even
diff --git a/proxy/logging/LogField.cc b/proxy/logging/LogField.cc
index cc57120..3ae1a0b 100644
--- a/proxy/logging/LogField.cc
+++ b/proxy/logging/LogField.cc
@@ -176,9 +176,20 @@ LogField::init_milestone_container(void)
 
 // Generic field ctor
 LogField::LogField(const char *name, const char *symbol, Type type, MarshalFunc marshal, UnmarshalFunc unmarshal, SetFunc _setfunc)
-  : m_name(ats_strdup(name)), m_symbol(ats_strdup(symbol)), m_type(type), m_container(NO_CONTAINER), m_marshal_func(marshal),
-    m_unmarshal_func(unmarshal), m_unmarshal_func_map(NULL), m_agg_op(NO_AGGREGATE), m_agg_cnt(0), m_agg_val(0),
-    m_milestone1(TS_MILESTONE_LAST_ENTRY), m_milestone2(TS_MILESTONE_LAST_ENTRY), m_time_field(false), m_alias_map(0),
+  : m_name(ats_strdup(name)),
+    m_symbol(ats_strdup(symbol)),
+    m_type(type),
+    m_container(NO_CONTAINER),
+    m_marshal_func(marshal),
+    m_unmarshal_func(unmarshal),
+    m_unmarshal_func_map(NULL),
+    m_agg_op(NO_AGGREGATE),
+    m_agg_cnt(0),
+    m_agg_val(0),
+    m_milestone1(TS_MILESTONE_LAST_ENTRY),
+    m_milestone2(TS_MILESTONE_LAST_ENTRY),
+    m_time_field(false),
+    m_alias_map(0),
     m_set_func(_setfunc)
 {
   ink_assert(m_name != NULL);
@@ -192,9 +203,20 @@ LogField::LogField(const char *name, const char *symbol, Type type, MarshalFunc
 
 LogField::LogField(const char *name, const char *symbol, Type type, MarshalFunc marshal, UnmarshalFuncWithMap unmarshal,
                    Ptr<LogFieldAliasMap> map, SetFunc _setfunc)
-  : m_name(ats_strdup(name)), m_symbol(ats_strdup(symbol)), m_type(type), m_container(NO_CONTAINER), m_marshal_func(marshal),
-    m_unmarshal_func(NULL), m_unmarshal_func_map(unmarshal), m_agg_op(NO_AGGREGATE), m_agg_cnt(0), m_agg_val(0),
-    m_milestone1(TS_MILESTONE_LAST_ENTRY), m_milestone2(TS_MILESTONE_LAST_ENTRY), m_time_field(false), m_alias_map(map),
+  : m_name(ats_strdup(name)),
+    m_symbol(ats_strdup(symbol)),
+    m_type(type),
+    m_container(NO_CONTAINER),
+    m_marshal_func(marshal),
+    m_unmarshal_func(NULL),
+    m_unmarshal_func_map(unmarshal),
+    m_agg_op(NO_AGGREGATE),
+    m_agg_cnt(0),
+    m_agg_val(0),
+    m_milestone1(TS_MILESTONE_LAST_ENTRY),
+    m_milestone2(TS_MILESTONE_LAST_ENTRY),
+    m_time_field(false),
+    m_alias_map(map),
     m_set_func(_setfunc)
 {
   ink_assert(m_name != NULL);
@@ -247,9 +269,20 @@ LogField::milestones_from_m_name(TSMilestonesType *ms1, TSMilestonesType *ms2)
 
 // Container field ctor
 LogField::LogField(const char *field, Container container, SetFunc _setfunc)
-  : m_name(ats_strdup(field)), m_symbol(ats_strdup(container_names[container])), m_type(LogField::STRING), m_container(container),
-    m_marshal_func(NULL), m_unmarshal_func(NULL), m_unmarshal_func_map(NULL), m_agg_op(NO_AGGREGATE), m_agg_cnt(0), m_agg_val(0),
-    m_milestone1(TS_MILESTONE_LAST_ENTRY), m_milestone2(TS_MILESTONE_LAST_ENTRY), m_time_field(false), m_alias_map(0),
+  : m_name(ats_strdup(field)),
+    m_symbol(ats_strdup(container_names[container])),
+    m_type(LogField::STRING),
+    m_container(container),
+    m_marshal_func(NULL),
+    m_unmarshal_func(NULL),
+    m_unmarshal_func_map(NULL),
+    m_agg_op(NO_AGGREGATE),
+    m_agg_cnt(0),
+    m_agg_val(0),
+    m_milestone1(TS_MILESTONE_LAST_ENTRY),
+    m_milestone2(TS_MILESTONE_LAST_ENTRY),
+    m_time_field(false),
+    m_alias_map(0),
     m_set_func(_setfunc)
 {
   ink_assert(m_name != NULL);
@@ -304,10 +337,21 @@ LogField::LogField(const char *field, Container container, SetFunc _setfunc)
 
 // Copy ctor
 LogField::LogField(const LogField &rhs)
-  : m_name(ats_strdup(rhs.m_name)), m_symbol(ats_strdup(rhs.m_symbol)), m_type(rhs.m_type), m_container(rhs.m_container),
-    m_marshal_func(rhs.m_marshal_func), m_unmarshal_func(rhs.m_unmarshal_func), m_unmarshal_func_map(rhs.m_unmarshal_func_map),
-    m_agg_op(rhs.m_agg_op), m_agg_cnt(0), m_agg_val(0), m_milestone1(TS_MILESTONE_LAST_ENTRY),
-    m_milestone2(TS_MILESTONE_LAST_ENTRY), m_time_field(rhs.m_time_field), m_alias_map(rhs.m_alias_map), m_set_func(rhs.m_set_func)
+  : m_name(ats_strdup(rhs.m_name)),
+    m_symbol(ats_strdup(rhs.m_symbol)),
+    m_type(rhs.m_type),
+    m_container(rhs.m_container),
+    m_marshal_func(rhs.m_marshal_func),
+    m_unmarshal_func(rhs.m_unmarshal_func),
+    m_unmarshal_func_map(rhs.m_unmarshal_func_map),
+    m_agg_op(rhs.m_agg_op),
+    m_agg_cnt(0),
+    m_agg_val(0),
+    m_milestone1(TS_MILESTONE_LAST_ENTRY),
+    m_milestone2(TS_MILESTONE_LAST_ENTRY),
+    m_time_field(rhs.m_time_field),
+    m_alias_map(rhs.m_alias_map),
+    m_set_func(rhs.m_set_func)
 {
   ink_assert(m_name != NULL);
   ink_assert(m_symbol != NULL);
diff --git a/proxy/logging/LogFile.cc b/proxy/logging/LogFile.cc
index 2fcdfe1..21cfb2b 100644
--- a/proxy/logging/LogFile.cc
+++ b/proxy/logging/LogFile.cc
@@ -63,7 +63,10 @@
 
 LogFile::LogFile(const char *name, const char *header, LogFileFormat format, uint64_t signature, size_t ascii_buffer_size,
                  size_t max_line_size)
-  : m_file_format(format), m_name(ats_strdup(name)), m_header(ats_strdup(header)), m_signature(signature),
+  : m_file_format(format),
+    m_name(ats_strdup(name)),
+    m_header(ats_strdup(header)),
+    m_signature(signature),
     m_max_line_size(max_line_size)
 {
   if (m_file_format != LOG_FILE_PIPE) {
@@ -86,8 +89,12 @@ LogFile::LogFile(const char *name, const char *header, LogFileFormat format, uin
   -------------------------------------------------------------------------*/
 
 LogFile::LogFile(const LogFile &copy)
-  : m_file_format(copy.m_file_format), m_name(ats_strdup(copy.m_name)), m_header(ats_strdup(copy.m_header)),
-    m_signature(copy.m_signature), m_ascii_buffer_size(copy.m_ascii_buffer_size), m_max_line_size(copy.m_max_line_size),
+  : m_file_format(copy.m_file_format),
+    m_name(ats_strdup(copy.m_name)),
+    m_header(ats_strdup(copy.m_header)),
+    m_signature(copy.m_signature),
+    m_ascii_buffer_size(copy.m_ascii_buffer_size),
+    m_max_line_size(copy.m_max_line_size),
     m_fd(copy.m_fd)
 {
   ink_release_assert(m_ascii_buffer_size >= m_max_line_size);
diff --git a/proxy/logging/LogFormat.cc b/proxy/logging/LogFormat.cc
index e1b1fae..b049cdc 100644
--- a/proxy/logging/LogFormat.cc
+++ b/proxy/logging/LogFormat.cc
@@ -183,8 +183,18 @@ LogFormat::init_variables(const char *name, const char *fieldlist_str, const cha
   -------------------------------------------------------------------------*/
 
 LogFormat::LogFormat(const char *name, const char *format_str, unsigned interval_sec)
-  : m_interval_sec(0), m_interval_next(0), m_agg_marshal_space(NULL), m_valid(false), m_name_str(NULL), m_name_id(0),
-    m_fieldlist_str(NULL), m_fieldlist_id(0), m_field_count(0), m_printf_str(NULL), m_aggregate(false), m_format_str(NULL)
+  : m_interval_sec(0),
+    m_interval_next(0),
+    m_agg_marshal_space(NULL),
+    m_valid(false),
+    m_name_str(NULL),
+    m_name_id(0),
+    m_fieldlist_str(NULL),
+    m_fieldlist_id(0),
+    m_field_count(0),
+    m_printf_str(NULL),
+    m_aggregate(false),
+    m_format_str(NULL)
 {
   setup(name, format_str, interval_sec);
 
@@ -202,8 +212,18 @@ LogFormat::LogFormat(const char *name, const char *format_str, unsigned interval
 // delete this.
 //
 LogFormat::LogFormat(const char *name, const char *fieldlist_str, const char *printf_str, unsigned interval_sec)
-  : m_interval_sec(0), m_interval_next(0), m_agg_marshal_space(NULL), m_valid(false), m_name_str(NULL), m_name_id(0),
-    m_fieldlist_str(NULL), m_fieldlist_id(0), m_field_count(0), m_printf_str(NULL), m_aggregate(false), m_format_str(NULL)
+  : m_interval_sec(0),
+    m_interval_next(0),
+    m_agg_marshal_space(NULL),
+    m_valid(false),
+    m_name_str(NULL),
+    m_name_id(0),
+    m_fieldlist_str(NULL),
+    m_fieldlist_id(0),
+    m_field_count(0),
+    m_printf_str(NULL),
+    m_aggregate(false),
+    m_format_str(NULL)
 {
   init_variables(name, fieldlist_str, printf_str, interval_sec);
   m_format_type = LOG_FORMAT_CUSTOM;
@@ -216,8 +236,18 @@ LogFormat::LogFormat(const char *name, const char *fieldlist_str, const char *pr
   -------------------------------------------------------------------------*/
 
 LogFormat::LogFormat(const LogFormat &rhs)
-  : m_interval_sec(0), m_interval_next(0), m_agg_marshal_space(NULL), m_valid(rhs.m_valid), m_name_str(NULL), m_name_id(0),
-    m_fieldlist_str(NULL), m_fieldlist_id(0), m_field_count(0), m_printf_str(NULL), m_aggregate(false), m_format_str(NULL),
+  : m_interval_sec(0),
+    m_interval_next(0),
+    m_agg_marshal_space(NULL),
+    m_valid(rhs.m_valid),
+    m_name_str(NULL),
+    m_name_id(0),
+    m_fieldlist_str(NULL),
+    m_fieldlist_id(0),
+    m_field_count(0),
+    m_printf_str(NULL),
+    m_aggregate(false),
+    m_format_str(NULL),
     m_format_type(rhs.m_format_type)
 {
   if (m_valid) {
diff --git a/proxy/logging/LogHost.cc b/proxy/logging/LogHost.cc
index 19f567c..b4efa96 100644
--- a/proxy/logging/LogHost.cc
+++ b/proxy/logging/LogHost.cc
@@ -51,16 +51,30 @@
   -------------------------------------------------------------------------*/
 
 LogHost::LogHost(const char *object_filename, uint64_t object_signature)
-  : m_object_filename(ats_strdup(object_filename)), m_object_signature(object_signature), m_port(0), m_name(NULL), m_sock(NULL),
-    m_sock_fd(-1), m_connected(false), m_orphan_file(NULL), m_log_collation_client_sm(NULL)
+  : m_object_filename(ats_strdup(object_filename)),
+    m_object_signature(object_signature),
+    m_port(0),
+    m_name(NULL),
+    m_sock(NULL),
+    m_sock_fd(-1),
+    m_connected(false),
+    m_orphan_file(NULL),
+    m_log_collation_client_sm(NULL)
 {
   ink_zero(m_ip);
   ink_zero(m_ipstr);
 }
 
 LogHost::LogHost(const LogHost &rhs)
-  : m_object_filename(ats_strdup(rhs.m_object_filename)), m_object_signature(rhs.m_object_signature), m_ip(rhs.m_ip), m_port(0),
-    m_name(ats_strdup(rhs.m_name)), m_sock(NULL), m_sock_fd(-1), m_connected(false), m_orphan_file(NULL),
+  : m_object_filename(ats_strdup(rhs.m_object_filename)),
+    m_object_signature(rhs.m_object_signature),
+    m_ip(rhs.m_ip),
+    m_port(0),
+    m_name(ats_strdup(rhs.m_name)),
+    m_sock(NULL),
+    m_sock_fd(-1),
+    m_connected(false),
+    m_orphan_file(NULL),
     m_log_collation_client_sm(NULL)
 {
   memcpy(m_ipstr, rhs.m_ipstr, sizeof(m_ipstr));
diff --git a/proxy/logging/LogObject.cc b/proxy/logging/LogObject.cc
index 3ac0acd..2ce619b 100644
--- a/proxy/logging/LogObject.cc
+++ b/proxy/logging/LogObject.cc
@@ -90,9 +90,16 @@ LogBufferManager::preproc_buffers(LogBufferSink *sink)
 LogObject::LogObject(const LogFormat *format, const char *log_dir, const char *basename, LogFileFormat file_format,
                      const char *header, Log::RollingEnabledValues rolling_enabled, int flush_threads, int rolling_interval_sec,
                      int rolling_offset_hr, int rolling_size_mb, bool auto_created)
-  : m_auto_created(auto_created), m_alt_filename(NULL), m_flags(0), m_signature(0), m_flush_threads(flush_threads),
-    m_rolling_interval_sec(rolling_interval_sec), m_rolling_offset_hr(rolling_offset_hr), m_rolling_size_mb(rolling_size_mb),
-    m_last_roll_time(0), m_buffer_manager_idx(0)
+  : m_auto_created(auto_created),
+    m_alt_filename(NULL),
+    m_flags(0),
+    m_signature(0),
+    m_flush_threads(flush_threads),
+    m_rolling_interval_sec(rolling_interval_sec),
+    m_rolling_offset_hr(rolling_offset_hr),
+    m_rolling_size_mb(rolling_size_mb),
+    m_last_roll_time(0),
+    m_buffer_manager_idx(0)
 {
   ink_release_assert(format);
   m_format = new LogFormat(*format);
@@ -124,9 +131,14 @@ LogObject::LogObject(const LogFormat *format, const char *log_dir, const char *b
 }
 
 LogObject::LogObject(LogObject &rhs)
-  : m_basename(ats_strdup(rhs.m_basename)), m_filename(ats_strdup(rhs.m_filename)), m_alt_filename(ats_strdup(rhs.m_alt_filename)),
-    m_flags(rhs.m_flags), m_signature(rhs.m_signature), m_flush_threads(rhs.m_flush_threads),
-    m_rolling_interval_sec(rhs.m_rolling_interval_sec), m_last_roll_time(rhs.m_last_roll_time)
+  : m_basename(ats_strdup(rhs.m_basename)),
+    m_filename(ats_strdup(rhs.m_filename)),
+    m_alt_filename(ats_strdup(rhs.m_alt_filename)),
+    m_flags(rhs.m_flags),
+    m_signature(rhs.m_signature),
+    m_flush_threads(rhs.m_flush_threads),
+    m_rolling_interval_sec(rhs.m_rolling_interval_sec),
+    m_last_roll_time(rhs.m_last_roll_time)
 {
   m_format = new LogFormat(*(rhs.m_format));
   m_buffer_manager = new LogBufferManager[m_flush_threads];
diff --git a/proxy/logstats.cc b/proxy/logstats.cc
index 707adcb..a326598 100644
--- a/proxy/logstats.cc
+++ b/proxy/logstats.cc
@@ -588,8 +588,18 @@ struct CommandLineArgs {
   int as_object;   // Show the URL stats as a single JSON object (not array)
 
   CommandLineArgs()
-    : max_origins(0), min_hits(0), max_age(0), line_len(DEFAULT_LINE_LEN), incremental(0), tail(0), summary(0), json(0), cgi(0),
-      urls(0), show_urls(0), as_object(0)
+    : max_origins(0),
+      min_hits(0),
+      max_age(0),
+      line_len(DEFAULT_LINE_LEN),
+      incremental(0),
+      tail(0),
+      summary(0),
+      json(0),
+      cgi(0),
+      urls(0),
+      show_urls(0),
+      as_object(0)
   {
     log_file[0] = '\0';
     origin_file[0] = '\0';
diff --git a/proxy/shared/UglyLogStubs.cc b/proxy/shared/UglyLogStubs.cc
index bbb3d0b..444864c 100644
--- a/proxy/shared/UglyLogStubs.cc
+++ b/proxy/shared/UglyLogStubs.cc
@@ -85,9 +85,21 @@ LogCollationAccept::~LogCollationAccept()
 
 #include "LogCollationClientSM.h"
 LogCollationClientSM::LogCollationClientSM(LogHost *log_host)
-  : Continuation(new_ProxyMutex()), m_host_vc(NULL), m_host_vio(NULL), m_auth_buffer(NULL), m_auth_reader(NULL),
-    m_send_buffer(NULL), m_send_reader(NULL), m_pending_action(NULL), m_pending_event(NULL), m_abort_vio(NULL),
-    m_abort_buffer(NULL), m_buffer_send_list(NULL), m_buffer_in_iocore(NULL), m_flow(LOG_COLL_FLOW_ALLOW), m_log_host(log_host),
+  : Continuation(new_ProxyMutex()),
+    m_host_vc(NULL),
+    m_host_vio(NULL),
+    m_auth_buffer(NULL),
+    m_auth_reader(NULL),
+    m_send_buffer(NULL),
+    m_send_reader(NULL),
+    m_pending_action(NULL),
+    m_pending_event(NULL),
+    m_abort_vio(NULL),
+    m_abort_buffer(NULL),
+    m_buffer_send_list(NULL),
+    m_buffer_in_iocore(NULL),
+    m_flow(LOG_COLL_FLOW_ALLOW),
+    m_log_host(log_host),
     m_id(0)
 {
 }
diff --git a/proxy/spdy/SpdyClientSession.h b/proxy/spdy/SpdyClientSession.h
index b089c29..6e24ce8 100644
--- a/proxy/spdy/SpdyClientSession.h
+++ b/proxy/spdy/SpdyClientSession.h
@@ -38,14 +38,30 @@ class SpdyRequest
 {
 public:
   SpdyRequest()
-    : event(0), spdy_sm(NULL), stream_id(-1), start_time(0), fetch_sm(NULL), has_submitted_data(false), need_resume_data(false),
-      fetch_data_len(0), delta_window_size(0), fetch_body_completed(false)
+    : event(0),
+      spdy_sm(NULL),
+      stream_id(-1),
+      start_time(0),
+      fetch_sm(NULL),
+      has_submitted_data(false),
+      need_resume_data(false),
+      fetch_data_len(0),
+      delta_window_size(0),
+      fetch_body_completed(false)
   {
   }
 
   SpdyRequest(SpdyClientSession *sm, int id)
-    : event(0), spdy_sm(NULL), stream_id(-1), start_time(0), fetch_sm(NULL), has_submitted_data(false), need_resume_data(false),
-      fetch_data_len(0), delta_window_size(0), fetch_body_completed(false)
+    : event(0),
+      spdy_sm(NULL),
+      stream_id(-1),
+      start_time(0),
+      fetch_sm(NULL),
+      has_submitted_data(false),
+      need_resume_data(false),
+      fetch_data_len(0),
+      delta_window_size(0),
+      fetch_body_completed(false)
   {
     init(sm, id);
   }
@@ -95,8 +111,19 @@ class SpdyClientSession : public ProxyClientSession, public PluginIdentity
 public:
   typedef ProxyClientSession super; ///< Parent type.
   SpdyClientSession()
-    : sm_id(0), version(spdy::SessionVersion::SESSION_VERSION_3_1), total_size(0), start_time(0), vc(NULL), req_buffer(NULL),
-      req_reader(NULL), resp_buffer(NULL), resp_reader(NULL), read_vio(NULL), write_vio(NULL), event(0), session(NULL)
+    : sm_id(0),
+      version(spdy::SessionVersion::SESSION_VERSION_3_1),
+      total_size(0),
+      start_time(0),
+      vc(NULL),
+      req_buffer(NULL),
+      req_reader(NULL),
+      resp_buffer(NULL),
+      resp_reader(NULL),
+      read_vio(NULL),
+      write_vio(NULL),
+      event(0),
+      session(NULL)
   {
   }
 

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.