You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by ig...@apache.org on 2012/11/21 15:48:32 UTC

git commit: TS-1582 space between string and format specifiers

Updated Branches:
  refs/heads/master 6dfedf8b1 -> b216afa33


TS-1582 space between string and format specifiers

GCC 4.7 (and newer versions of clang) REQUIRE a space between
the format the string and a format specifier (a # defined "string")
in an string concatenation to be C++11 conformant.


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

Branch: refs/heads/master
Commit: b216afa33aa6e52d1e4502e46db6c34a8635d2c9
Parents: 6dfedf8
Author: Luca Rea <lr...@gmail.com>
Authored: Wed Nov 21 12:39:48 2012 +0100
Committer: Igor Galić <i....@brainsware.org>
Committed: Wed Nov 21 12:39:48 2012 +0100

----------------------------------------------------------------------
 iocore/cache/Cache.cc                       |   10 ++++----
 iocore/cache/CacheDir.cc                    |    4 +-
 iocore/cache/CacheHosting.cc                |    6 ++--
 iocore/cache/CacheRead.cc                   |   12 +++++-----
 iocore/cache/CacheWrite.cc                  |    6 ++--
 iocore/cache/RamCacheCLFUS.cc               |    2 +-
 iocore/cluster/ClusterCache.cc              |    2 +-
 iocore/cluster/ClusterHandler.cc            |   12 +++++-----
 iocore/hostdb/HostDB.cc                     |    4 +-
 iocore/net/SSLNetVConnection.cc             |    8 +++---
 iocore/net/Socks.cc                         |    2 +-
 iocore/utils/OneWayTunnel.cc                |    2 +-
 lib/records/RecHttp.cc                      |    2 +-
 mgmt/api/CoreAPI.cc                         |    4 +-
 plugins/conf_remap/conf_remap.cc            |    2 +-
 plugins/experimental/esi/plugin.cc          |    6 ++--
 plugins/experimental/esi/serverIntercept.cc |    2 +-
 plugins/experimental/gzip/misc.cc           |    4 +-
 proxy/FetchSM.cc                            |    6 ++--
 proxy/InkAPITest.cc                         |   12 +++++-----
 proxy/InkAPITestTool.cc                     |   12 +++++-----
 proxy/PluginVC.cc                           |   12 +++++-----
 proxy/Prefetch.cc                           |    6 ++--
 proxy/StatSystem.cc                         |    2 +-
 proxy/Transform.cc                          |    8 +++---
 proxy/Update.cc                             |    6 ++--
 proxy/http/HttpBodyFactory.cc               |   18 ++++++++--------
 proxy/http/HttpClientSession.cc             |    2 +-
 proxy/http/HttpConfig.cc                    |    4 +-
 proxy/http/HttpSM.cc                        |    8 +++---
 proxy/http/HttpTransact.cc                  |   12 +++++-----
 proxy/http/HttpTunnel.cc                    |   24 +++++++++++-----------
 proxy/logging/LogCollationHostSM.cc         |    4 +-
 proxy/logging/LogField.cc                   |    4 +-
 tools/jtest/jtest.cc                        |   22 ++++++++++----------
 35 files changed, 126 insertions(+), 126 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/Cache.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/Cache.cc b/iocore/cache/Cache.cc
index a80ee35..4cb67e9 100644
--- a/iocore/cache/Cache.cc
+++ b/iocore/cache/Cache.cc
@@ -688,10 +688,10 @@ CacheProcessor::diskInitialized()
         Debug("cache_hosting", "Disk: %d: Vol Blocks: %u: Free space: %" PRIu64,
               i, d->header->num_diskvol_blks, d->free_space);
         for (j = 0; j < (int) d->header->num_volumes; j++) {
-          Debug("cache_hosting", "\tVol: %d Size: %"PRIu64, d->disk_vols[j]->vol_number, d->disk_vols[j]->size);
+          Debug("cache_hosting", "\tVol: %d Size: %" PRIu64, d->disk_vols[j]->vol_number, d->disk_vols[j]->size);
         }
         for (j = 0; j < (int) d->header->num_diskvol_blks; j++) {
-          Debug("cache_hosting", "\tBlock No: %d Size: %"PRIu64" Free: %u",
+          Debug("cache_hosting", "\tBlock No: %d Size: %" PRIu64" Free: %u",
                 d->header->vol_info[j].number, d->header->vol_info[j].len, d->header->vol_info[j].free);
         }
       }
@@ -1910,7 +1910,7 @@ CacheVC::handleReadDone(int event, Event *e) {
     if (is_debug_tag_set("cache_read")) {
       char xt[33];
       Debug("cache_read"
-            , "Read complete on fragment %s. Length: data payload=%d this fragment=%d total doc=%"PRId64" prefix=%d"
+            , "Read complete on fragment %s. Length: data payload=%d this fragment=%d total doc=%" PRId64" prefix=%d"
             , doc->key.toHexStr(xt), doc->data_len(), doc->len, doc->total_len, doc->prefix_len()
         );
     }
@@ -2380,11 +2380,11 @@ cplist_reconfigure()
         percent_remaining -= (config_vol->size < 128) ? 0 : config_vol->percent;
       }
       if (config_vol->size < 128) {
-        Warning("the size of volume %d (%"PRId64") is less than the minimum required volume size %d",
+        Warning("the size of volume %d (%" PRId64") is less than the minimum required volume size %d",
                 config_vol->number, (int64_t)config_vol->size, 128);
         Warning("volume %d is not created", config_vol->number);
       }
-      Debug("cache_hosting", "Volume: %d Size: %"PRId64, config_vol->number, (int64_t)config_vol->size);
+      Debug("cache_hosting", "Volume: %d Size: %" PRId64, config_vol->number, (int64_t)config_vol->size);
     }
     cplist_update();
     /* go through volume config and grow and create volumes */

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/CacheDir.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CacheDir.cc b/iocore/cache/CacheDir.cc
index ffc6fff..90e7d0e 100644
--- a/iocore/cache/CacheDir.cc
+++ b/iocore/cache/CacheDir.cc
@@ -776,7 +776,7 @@ dir_lookaside_fixup(CacheKey *key, Vol *d)
   while (b) {
     if (b->evac_frags.key == *key) {
       int res = dir_overwrite(key, d, &b->new_dir, &b->dir, false);
-      DDebug("dir_lookaside", "fixup %X %X offset %"PRId64" phase %d %d",
+      DDebug("dir_lookaside", "fixup %X %X offset %" PRId64" phase %d %d",
             key->word(0), key->word(1), dir_offset(&b->new_dir), dir_phase(&b->new_dir), res);
       int64_t o = dir_offset(&b->dir), n = dir_offset(&b->new_dir);
       d->ram_cache->fixup(key, (uint32_t)(o >> 32), (uint32_t)o, (uint32_t)(n >> 32), (uint32_t)n);
@@ -821,7 +821,7 @@ dir_lookaside_remove(CacheKey *key, Vol *d)
   EvacuationBlock *b = d->lookaside[i].head;
   while (b) {
     if (b->evac_frags.key == *key) {
-      DDebug("dir_lookaside", "remove %X %X offset %"PRId64" phase %d",
+      DDebug("dir_lookaside", "remove %X %X offset %" PRId64" phase %d",
             key->word(0), key->word(1), dir_offset(&b->new_dir), dir_phase(&b->new_dir));
       d->lookaside[i].remove(b);
       free_EvacuationBlock(b, d->mutex->thread_holding);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/CacheHosting.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CacheHosting.cc b/iocore/cache/CacheHosting.cc
index 05b9014..dccc014 100644
--- a/iocore/cache/CacheHosting.cc
+++ b/iocore/cache/CacheHosting.cc
@@ -457,7 +457,7 @@ CacheHostRecord::Init(int typ)
   CacheVol *cachep = cp_list.head;
   for (; cachep; cachep = cachep->link.next) {
     if (cachep->scheme == type) {
-      Debug("cache_hosting", "Host Record: %p, Volume: %d, size: %"PRId64, this, cachep->vol_number, (int64_t)cachep->size);
+      Debug("cache_hosting", "Host Record: %p, Volume: %d, size: %" PRId64, this, cachep->vol_number, (int64_t)cachep->size);
       cp[num_cachevols] = cachep;
       num_cachevols++;
       num_vols += cachep->num_vols;
@@ -1146,10 +1146,10 @@ execute_and_verify(RegressionTest * t)
             i, d->header->num_diskvol_blks, d->free_space);
       for (int j = 0; j < (int) d->header->num_volumes; j++) {
 
-        Debug("cache_hosting", "\tVol: %d Size: %"PRIu64, d->disk_vols[j]->vol_number, d->disk_vols[j]->size);
+        Debug("cache_hosting", "\tVol: %d Size: %" PRIu64, d->disk_vols[j]->vol_number, d->disk_vols[j]->size);
       }
       for (int j = 0; j < (int) d->header->num_diskvol_blks; j++) {
-        Debug("cache_hosting", "\tBlock No: %d Size: %"PRIu64" Free: %u",
+        Debug("cache_hosting", "\tBlock No: %d Size: %" PRIu64" Free: %u",
               d->header->vol_info[j].number, d->header->vol_info[j].len, d->header->vol_info[j].free);
       }
     }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/CacheRead.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CacheRead.cc b/iocore/cache/CacheRead.cc
index f82f1dd..1faab20 100644
--- a/iocore/cache/CacheRead.cc
+++ b/iocore/cache/CacheRead.cc
@@ -627,7 +627,7 @@ CacheVC::openReadMain(int event, Event * e)
     HTTPInfo::FragOffset* frags = alternate.get_frag_table();
     if (is_debug_tag_set("cache_seek")) {
       char b[33], c[33];
-      Debug("cache_seek", "Seek @ %"PRId64" in %s from #%d @ %"PRId64"/%d:%s",
+      Debug("cache_seek", "Seek @ %" PRId64" in %s from #%d @ %" PRId64"/%d:%s",
             seek_to, first_key.toHexStr(b), fragment, doc_pos, doc->len, doc->key.toHexStr(c));
     }
     /* Because single fragment objects can migrate to hang off an alt vector
@@ -675,7 +675,7 @@ CacheVC::openReadMain(int event, Event * e)
         if (is_debug_tag_set("cache_seek")) {
           char target_key_str[33];
           key.toHexStr(target_key_str);
-          Debug("cache_seek", "Seek #%d @ %"PRId64" -> #%d @ %"PRId64":%s", cfi, doc_pos, target, seek_to, target_key_str);
+          Debug("cache_seek", "Seek #%d @ %" PRId64" -> #%d @ %" PRId64":%s", cfi, doc_pos, target, seek_to, target_key_str);
         }
         goto Lread;
       }
@@ -689,7 +689,7 @@ CacheVC::openReadMain(int event, Event * e)
     if (is_debug_tag_set("cache_seek")) {
       char target_key_str[33];
       key.toHexStr(target_key_str);
-      Debug("cache_seek", "Read # %d @ %"PRId64"/%d for %"PRId64, fragment, doc_pos, doc->len, bytes);
+      Debug("cache_seek", "Read # %d @ %" PRId64"/%d for %" PRId64, fragment, doc_pos, doc->len, bytes);
     }
   }
   if (ntodo <= 0)
@@ -832,7 +832,7 @@ CacheVC::openReadStartEarliest(int event, Event * e)
 #ifdef HIT_EVACUATE
     if (vol->within_hit_evacuate_window(&earliest_dir) &&
         (!cache_config_hit_evacuate_size_limit || doc_len <= (uint64_t)cache_config_hit_evacuate_size_limit)) {
-      DDebug("cache_hit_evac", "dir: %"PRId64", write: %"PRId64", phase: %d",
+      DDebug("cache_hit_evac", "dir: %" PRId64", write: %" PRId64", phase: %d",
             dir_offset(&earliest_dir), offset_to_vol_offset(vol, vol->header->write_pos), vol->header->phase);
       f.hit_evacuate = 1;
     }
@@ -1088,7 +1088,7 @@ CacheVC::openReadStartHead(int event, Event * e)
 
     if (is_debug_tag_set("cache_read")) { // amc debug
       char xt[33],yt[33];
-      Debug("cache_read", "CacheReadStartHead - read %s target %s - %s %d of %"PRId64" bytes, %d fragments",
+      Debug("cache_read", "CacheReadStartHead - read %s target %s - %s %d of %" PRId64" bytes, %d fragments",
             doc->key.toHexStr(xt), key.toHexStr(yt),
             f.single_fragment ? "single" : "multi",
             doc->len, doc->total_len, alternate.get_frag_offset_count());
@@ -1101,7 +1101,7 @@ CacheVC::openReadStartHead(int event, Event * e)
 #ifdef HIT_EVACUATE
     if (vol->within_hit_evacuate_window(&dir) &&
         (!cache_config_hit_evacuate_size_limit || doc_len <= (uint64_t)cache_config_hit_evacuate_size_limit)) {
-      DDebug("cache_hit_evac", "dir: %"PRId64", write: %"PRId64", phase: %d",
+      DDebug("cache_hit_evac", "dir: %" PRId64", write: %" PRId64", phase: %d",
             dir_offset(&dir), offset_to_vol_offset(vol, vol->header->write_pos), vol->header->phase);
       f.hit_evacuate = 1;
     }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/CacheWrite.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CacheWrite.cc b/iocore/cache/CacheWrite.cc
index 841b20d..b93839d 100644
--- a/iocore/cache/CacheWrite.cc
+++ b/iocore/cache/CacheWrite.cc
@@ -422,7 +422,7 @@ CacheVC::evacuateReadHead(int event, Event *e)
       goto Ldone;
     alternate_tmp = vector.get(alternate_index);
     doc_len = alternate_tmp->object_size_get();
-    Debug("cache_evac", "evacuateReadHead http earliest %X first: %X len: %"PRId64,
+    Debug("cache_evac", "evacuateReadHead http earliest %X first: %X len: %" PRId64,
           first_key.word(0), earliest_key.word(0), doc_len);
   } else
 #endif
@@ -434,7 +434,7 @@ CacheVC::evacuateReadHead(int event, Event *e)
       goto Ldone;
     doc_len = doc->total_len;
     DDebug("cache_evac",
-          "evacuateReadHead non-http earliest %X first: %X len: %"PRId64, first_key.word(0), earliest_key.word(0), doc_len);
+          "evacuateReadHead non-http earliest %X first: %X len: %" PRId64, first_key.word(0), earliest_key.word(0), doc_len);
   }
   if (doc_len == total_len) {
     // the whole document has been evacuated. Insert the directory
@@ -1500,7 +1500,7 @@ CacheVC::openWriteStartDone(int event, Event *e)
        */
       if (!dir_valid(vol, &dir)) {
         DDebug("cache_write",
-               "OpenReadStartDone: Dir not valid: Write Head: %" PRId64 ", Dir: %"PRId64,
+               "OpenReadStartDone: Dir not valid: Write Head: %" PRId64 ", Dir: %" PRId64,
                (int64_t)offset_to_vol_offset(vol, vol->header->write_pos), dir_offset(&dir));
         last_collision = NULL;
         goto Lcollision;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cache/RamCacheCLFUS.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/RamCacheCLFUS.cc b/iocore/cache/RamCacheCLFUS.cc
index 69feb42..c507eb8 100644
--- a/iocore/cache/RamCacheCLFUS.cc
+++ b/iocore/cache/RamCacheCLFUS.cc
@@ -525,7 +525,7 @@ int RamCacheCLFUS::put(INK_MD5 *key, IOBufferData *data, uint32_t len, bool copy
       if (bytes + victim->size + size > max_bytes && CACHE_VALUE(victim) > CACHE_VALUE(e)) {
         requeue_victims(this, victims);
         lru[1].enqueue(e);
-        DDebug("ram_cache", "put %X %d %d size %d INC %"PRId64" HISTORY",
+        DDebug("ram_cache", "put %X %d %d size %d INC %" PRId64" HISTORY",
                key->word(3), auxkey1, auxkey2, e->size, e->hits);
         return 0;
       }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cluster/ClusterCache.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterCache.cc b/iocore/cluster/ClusterCache.cc
index ac5599d..06a23d2 100644
--- a/iocore/cluster/ClusterCache.cc
+++ b/iocore/cluster/ClusterCache.cc
@@ -1781,7 +1781,7 @@ CacheContinuation::replyOpEvent(int event, VConnection * cvc)
   if (vers == CacheOpReplyMsg::CACHE_OP_REPLY_MESSAGE_VERSION) {
     if (read_op) {
       // Transmit reply message and object data in same cluster message
-      Debug("cache_proto", "Sending reply/data seqno=%d buflen=%"PRId64,
+      Debug("cache_proto", "Sending reply/data seqno=%d buflen=%" PRId64,
             seq_number, readahead_data ? bytes_IOBufferBlockList(readahead_data, 1) : 0);
       clusterProcessor.invoke_remote_data(ch,
                                           CACHE_OP_RESULT_CLUSTER_FUNCTION,

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/cluster/ClusterHandler.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterHandler.cc b/iocore/cluster/ClusterHandler.cc
index e67f025..6e4c5ca 100644
--- a/iocore/cluster/ClusterHandler.cc
+++ b/iocore/cluster/ClusterHandler.cc
@@ -780,7 +780,7 @@ bool ClusterHandler::get_read_locks()
       int64_t read_avail = vc->read_block->read_avail();
 
       if (!vc->pending_remote_fill && read_avail) {
-        Debug("cluster_vc_xfer", "Deferred fill ch %d %p %"PRId64" bytes", vc->channel, vc, read_avail);
+        Debug("cluster_vc_xfer", "Deferred fill ch %d %p %" PRId64" bytes", vc->channel, vc, read_avail);
 
         vc->read.vio.buffer.writer()->append_block(vc->read_block->clone());
         if (complete_channel_read(read_avail, vc)) {
@@ -1436,7 +1436,7 @@ ClusterHandler::finish_delayed_reads()
             ClusterVC_remove_read(vc);
           }
           Debug("cluster_vc_xfer",
-                "Delayed read, credit ch %d %p %"PRId64" bytes", vc->channel, vc, d->get_block()->read_avail());
+                "Delayed read, credit ch %d %p %" PRId64" bytes", vc->channel, vc, d->get_block()->read_avail());
           vc->read.vio.buffer.writer()->append_block(d->get_block());
 
           if (complete_channel_read(d->get_block()->read_avail(), vc)) {
@@ -1485,7 +1485,7 @@ ClusterHandler::update_channels_written(bool bump_unhandled_channels)
           int len = write.msg.descriptor[i].length;
           vc->write_bytes_in_transit -= len;
           ink_release_assert(vc->write_bytes_in_transit >= 0);
-          Debug(CL_PROTO, "(%d) data sent %d %"PRId64, write.msg.descriptor[i].channel, len, s->vio.ndone);
+          Debug(CL_PROTO, "(%d) data sent %d %" PRId64, write.msg.descriptor[i].channel, len, s->vio.ndone);
 
           if (vc_ok_write(vc)) {
             vc->last_activity_time = current_time;      // note activity time
@@ -2221,7 +2221,7 @@ retry:
     // Push initial read data into VC
 
     if (ntodo >= bytes_to_move) {
-      Debug("cluster_vc_xfer", "finish initial data push ch %d bytes %"PRId64, vc->channel, vc->read_block->read_avail());
+      Debug("cluster_vc_xfer", "finish initial data push ch %d bytes %" PRId64, vc->channel, vc->read_block->read_avail());
 
       s->vio.buffer.writer()->append_block(vc->read_block->clone());
       vc->read_block = 0;
@@ -2229,7 +2229,7 @@ retry:
     } else {
       bytes_to_move = ntodo;
 
-      Debug("cluster_vc_xfer", "initial data push ch %d bytes %"PRId64, vc->channel, bytes_to_move);
+      Debug("cluster_vc_xfer", "initial data push ch %d bytes %" PRId64, vc->channel, bytes_to_move);
 
       // Clone a portion of the data
 
@@ -2284,7 +2284,7 @@ retry:
   }
 
   if ((vc->last_local_free == 0) || (nextfree >= vc->last_local_free)) {
-    Debug(CL_PROTO, "(%d) update freespace %"PRId64, vc->channel, nextfree);
+    Debug(CL_PROTO, "(%d) update freespace %" PRId64, vc->channel, nextfree);
     cluster_update_priority(this, vc, s, nextfree - vc->last_local_free, nb);
     cluster_reschedule(this, vc, s);
     //

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/hostdb/HostDB.cc
----------------------------------------------------------------------
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index 4c17f5a..b05b4f7 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -558,7 +558,7 @@ probe(ProxyMutex *mutex, INK_MD5 & md5, const char *hostname, int len, sockaddr
   if (hostdb_enable) {
     uint64_t folded_md5 = fold_md5(md5);
     HostDBInfo *r = hostDB.lookup_block(folded_md5, hostDB.levels);
-    Debug("hostdb", "probe %s %"PRIx64" %d [ignore_timeout = %d]", hostname, folded_md5, !!r, ignore_timeout);
+    Debug("hostdb", "probe %s %" PRIx64" %d [ignore_timeout = %d]", hostname, folded_md5, !!r, ignore_timeout);
     if (r && md5[1] == r->md5_high) {
 
       // Check for timeout (fail probe)
@@ -636,7 +636,7 @@ HostDBContinuation::insert(unsigned int attl)
     attl = HOST_DB_MAX_TTL;
   r->ip_timeout_interval = attl;
   r->ip_timestamp = hostdb_current_interval;
-  Debug("hostdb", "inserting for: %s: (md5: %"PRIx64") now: %u timeout: %u ttl: %u", name, folded_md5, r->ip_timestamp,
+  Debug("hostdb", "inserting for: %s: (md5: %" PRIx64") now: %u timeout: %u ttl: %u", name, folded_md5, r->ip_timestamp,
         r->ip_timeout_interval, attl);
   return r;
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/net/SSLNetVConnection.cc
----------------------------------------------------------------------
diff --git a/iocore/net/SSLNetVConnection.cc b/iocore/net/SSLNetVConnection.cc
index 3f4e8ca..5251345 100644
--- a/iocore/net/SSLNetVConnection.cc
+++ b/iocore/net/SSLNetVConnection.cc
@@ -89,7 +89,7 @@ ssl_read_from_net(NetHandler * nh, UnixNetVConnection * vc, EThread * lthread, i
   for (bytes_read = 0; (b != 0) && (sslErr == SSL_ERROR_NONE); b = b->next) {
     block_write_avail = b->write_avail();
 
-    Debug("ssl", "[SSL_NetVConnection::ssl_read_from_net] b->write_avail()=%"PRId64, block_write_avail);
+    Debug("ssl", "[SSL_NetVConnection::ssl_read_from_net] b->write_avail()=%" PRId64, block_write_avail);
 
     int64_t offset = 0;
     // while can be replaced with if - need to test what works faster with openssl
@@ -155,7 +155,7 @@ ssl_read_from_net(NetHandler * nh, UnixNetVConnection * vc, EThread * lthread, i
   }                             // for ( bytes_read = 0; (b != 0); b = b->next)
 
   if (bytes_read > 0) {
-    Debug("ssl", "[SSL_NetVConnection::ssl_read_from_net] bytes_read=%"PRId64, bytes_read);
+    Debug("ssl", "[SSL_NetVConnection::ssl_read_from_net] bytes_read=%" PRId64, bytes_read);
     buf.writer()->fill(bytes_read);
     s->vio.ndone += bytes_read;
     vc->netActivity(lthread);
@@ -348,7 +348,7 @@ SSLNetVConnection::load_buffer_and_write(int64_t towrite, int64_t &wattempted, i
       break;
     wattempted = l;
     total_wrote += l;
-    Debug("ssl", "SSLNetVConnection::loadBufferAndCallWrite, before do_SSL_write, l=%"PRId64", towrite=%"PRId64", b=%p",
+    Debug("ssl", "SSLNetVConnection::loadBufferAndCallWrite, before do_SSL_write, l=%" PRId64", towrite=%" PRId64", b=%p",
           l, towrite, b);
     r = do_SSL_write(ssl, b->start() + offset, (int)l);
     if (r == l) {
@@ -357,7 +357,7 @@ SSLNetVConnection::load_buffer_and_write(int64_t towrite, int64_t &wattempted, i
     // on to the next block
     offset = 0;
     b = b->next;
-    Debug("ssl", "SSLNetVConnection::loadBufferAndCallWrite,Number of bytes written=%"PRId64" , total=%"PRId64"", r, total_wrote);
+    Debug("ssl", "SSLNetVConnection::loadBufferAndCallWrite,Number of bytes written=%" PRId64" , total=%" PRId64"", r, total_wrote);
     NET_DEBUG_COUNT_DYN_STAT(net_calls_to_write_stat, 1);
   } while (r == l && total_wrote < towrite && b);
   if (r > 0) {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/net/Socks.cc
----------------------------------------------------------------------
diff --git a/iocore/net/Socks.cc b/iocore/net/Socks.cc
index 70ef9ff..4a42e52 100644
--- a/iocore/net/Socks.cc
+++ b/iocore/net/Socks.cc
@@ -403,7 +403,7 @@ SocksEntry::mainEvent(int event, void *data)
       bool success;
       if (version == SOCKS5_VERSION) {
         success = (p[0] == SOCKS5_VERSION && p[1] == SOCKS5_REQ_GRANTED);
-        Debug("Socks", "received reply of length %"PRId64" addr type %d", ((VIO *) data)->ndone, (int) p[3]);
+        Debug("Socks", "received reply of length %" PRId64" addr type %d", ((VIO *) data)->ndone, (int) p[3]);
       } else
         success = (p[0] == 0 && p[1] == SOCKS4_REQ_GRANTED);
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/iocore/utils/OneWayTunnel.cc
----------------------------------------------------------------------
diff --git a/iocore/utils/OneWayTunnel.cc b/iocore/utils/OneWayTunnel.cc
index 34ce210..afac1db 100644
--- a/iocore/utils/OneWayTunnel.cc
+++ b/iocore/utils/OneWayTunnel.cc
@@ -140,7 +140,7 @@ OneWayTunnel::init(VConnection * vcSource,
   else
     size_index = default_large_iobuffer_size;
 
-  Debug("one_way_tunnel", "buffer size index [%"PRId64"] [%d]\n", size_index, size_estimate);
+  Debug("one_way_tunnel", "buffer size index [%" PRId64"] [%d]\n", size_index, size_estimate);
 
   // enqueue read request on vcSource.
   MIOBuffer *buf1 = new_MIOBuffer(size_index);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/lib/records/RecHttp.cc
----------------------------------------------------------------------
diff --git a/lib/records/RecHttp.cc b/lib/records/RecHttp.cc
index de53661..37cecfa 100644
--- a/lib/records/RecHttp.cc
+++ b/lib/records/RecHttp.cc
@@ -178,7 +178,7 @@ HttpProxyPort::loadConfig(Vec<self>& entries) {
       } else if (-1 != ssl_port) {
 	// -1 is used as the sentinel value in the config record for
 	// "not set by user".
-        Warning("SSL enabled but port value %"PRId64" is not in the range 1..65535.\n",
+        Warning("SSL enabled but port value %" PRId64" is not in the range 1..65535.\n",
                 ssl_port);
       }
     }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/mgmt/api/CoreAPI.cc
----------------------------------------------------------------------
diff --git a/mgmt/api/CoreAPI.cc b/mgmt/api/CoreAPI.cc
index 93a90a0..68f4d10 100644
--- a/mgmt/api/CoreAPI.cc
+++ b/mgmt/api/CoreAPI.cc
@@ -325,7 +325,7 @@ MgmtRecordGet(const char *rec_name, TSRecordEle * rec_ele)
       return TS_ERR_FAIL;
     rec_ele->counter_val = (TSCounter) counter_val;
 
-    Debug("RecOp", "[MgmtRecordGet] Get Counter Var %s = %"PRId64"\n", rec_ele->rec_name, rec_ele->counter_val);
+    Debug("RecOp", "[MgmtRecordGet] Get Counter Var %s = %" PRId64"\n", rec_ele->rec_name, rec_ele->counter_val);
     break;
 
   case RECD_INT:
@@ -334,7 +334,7 @@ MgmtRecordGet(const char *rec_name, TSRecordEle * rec_ele)
       return TS_ERR_FAIL;
     rec_ele->int_val = (TSInt) int_val;
 
-    Debug("RecOp", "[MgmtRecordGet] Get Int Var %s = %"PRId64"\n", rec_ele->rec_name, rec_ele->int_val);
+    Debug("RecOp", "[MgmtRecordGet] Get Int Var %s = %" PRId64"\n", rec_ele->rec_name, rec_ele->int_val);
     break;
 
   case RECD_FLOAT:

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/plugins/conf_remap/conf_remap.cc
----------------------------------------------------------------------
diff --git a/plugins/conf_remap/conf_remap.cc b/plugins/conf_remap/conf_remap.cc
index 0e6e048..11d2a97 100644
--- a/plugins/conf_remap/conf_remap.cc
+++ b/plugins/conf_remap/conf_remap.cc
@@ -244,7 +244,7 @@ TSRemapDoRemap(void* ih, TSHttpTxn rh, TSRemapRequestInfo *rri)
       switch (conf->_items[ix]._type) {
       case TS_RECORDDATATYPE_INT:
         TSHttpTxnConfigIntSet(txnp, conf->_items[ix]._name, conf->_items[ix]._data.rec_int);
-        TSDebug(PLUGIN_NAME, "Setting config id %d to %"PRId64"", conf->_items[ix]._name, conf->_items[ix]._data.rec_int);
+        TSDebug(PLUGIN_NAME, "Setting config id %d to %" PRId64"", conf->_items[ix]._name, conf->_items[ix]._data.rec_int);
         break;
       case TS_RECORDDATATYPE_STRING:
         TSHttpTxnConfigStringSet(txnp, conf->_items[ix]._name, conf->_items[ix]._data.rec_string, conf->_items[ix]._data_len);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/plugins/experimental/esi/plugin.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/plugin.cc b/plugins/experimental/esi/plugin.cc
index 72397d9..1c21172 100644
--- a/plugins/experimental/esi/plugin.cc
+++ b/plugins/experimental/esi/plugin.cc
@@ -621,7 +621,7 @@ transformData(TSCont contp)
   if (!process_input_complete && (cont_data->curr_state == ContData::READING_ESI_DOC)) {
     // Determine how much data we have left to read.
     toread = TSVIONTodoGet(cont_data->input_vio);
-    TSDebug(cont_data->debug_tag, "[%s] upstream VC has %"PRId64" bytes available to read",
+    TSDebug(cont_data->debug_tag, "[%s] upstream VC has %" PRId64" bytes available to read",
              __FUNCTION__, toread);
 
     if (toread > 0) {
@@ -647,14 +647,14 @@ transformData(TSCont contp)
             cont_data->packed_node_list.append(data, data_len);
           }
           TSDebug(cont_data->debug_tag,
-                   "[%s] Added chunk of %"PRId64" bytes starting with [%.10s] to parse list",
+                   "[%s] Added chunk of %" PRId64" bytes starting with [%.10s] to parse list",
                    __FUNCTION__, data_len, (data_len ? data : "(null)"));
           consumed += data_len;
 
           block = TSIOBufferBlockNext(block);
         }
       }
-      TSDebug(cont_data->debug_tag, "[%s] Consumed %"PRId64" bytes from upstream VC",
+      TSDebug(cont_data->debug_tag, "[%s] Consumed %" PRId64" bytes from upstream VC",
                __FUNCTION__, consumed);
 
       TSIOBufferReaderConsume(cont_data->input_reader, consumed);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/plugins/experimental/esi/serverIntercept.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/esi/serverIntercept.cc b/plugins/experimental/esi/serverIntercept.cc
index 8f3620c..e8fc464 100644
--- a/plugins/experimental/esi/serverIntercept.cc
+++ b/plugins/experimental/esi/serverIntercept.cc
@@ -173,7 +173,7 @@ handleRead(SContData *cont_data, bool &read_complete) {
           cont_data->req_hdr_parsed = true;
         }
       } else {
-        TSDebug(DEBUG_TAG, "[%s] Appending %"PRId64" bytes to body", __FUNCTION__, data_len);
+        TSDebug(DEBUG_TAG, "[%s] Appending %" PRId64" bytes to body", __FUNCTION__, data_len);
         cont_data->body.append(data, data_len);
       }
       consumed += data_len;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/plugins/experimental/gzip/misc.cc
----------------------------------------------------------------------
diff --git a/plugins/experimental/gzip/misc.cc b/plugins/experimental/gzip/misc.cc
index d830bbf..637ba4b 100644
--- a/plugins/experimental/gzip/misc.cc
+++ b/plugins/experimental/gzip/misc.cc
@@ -203,8 +203,8 @@ void
 gzip_log_ratio(int64_t in, int64_t out)
 {
   if (in) {
-    info("Compressed size %"PRId64" (bytes), Original size %"PRId64", ratio: %f", out, in, ((float) (in - out) / in));
+    info("Compressed size %" PRId64" (bytes), Original size %" PRId64", ratio: %f", out, in, ((float) (in - out) / in));
   } else {
-    debug("Compressed size %"PRId64" (bytes), Original size %"PRId64", ratio: %f", out, in, 0.0F);
+    debug("Compressed size %" PRId64" (bytes), Original size %" PRId64", ratio: %f", out, in, 0.0F);
   }
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/FetchSM.cc
----------------------------------------------------------------------
diff --git a/proxy/FetchSM.cc b/proxy/FetchSM.cc
index af1ae71..bf78aba 100644
--- a/proxy/FetchSM.cc
+++ b/proxy/FetchSM.cc
@@ -132,7 +132,7 @@ FetchSM::process_fetch_read(int event)
   switch (event) {
   case TS_EVENT_VCONN_READ_READY:
     bytes = resp_reader->read_avail();
-    Debug(DEBUG_TAG, "[%s] number of bytes in read ready %"PRId64"", __FUNCTION__, bytes);
+    Debug(DEBUG_TAG, "[%s] number of bytes in read ready %" PRId64"", __FUNCTION__, bytes);
     while (total_bytes_copied < bytes) {
        int64_t actual_bytes_copied;
        actual_bytes_copied = response_buffer->write(resp_reader, bytes, 0);
@@ -157,11 +157,11 @@ FetchSM::process_fetch_read(int event)
     bytes = response_reader->read_avail();
 
     get_info_from_buffer(response_reader);
-    Debug(DEBUG_TAG, "[%s] number of bytes %"PRId64"", __FUNCTION__, bytes);
+    Debug(DEBUG_TAG, "[%s] number of bytes %" PRId64"", __FUNCTION__, bytes);
     if(client_response!=NULL)
       client_response[bytes] = '\0';
       //client_response[bytes + _headers.size()] = '\0';
-    Debug(DEBUG_TAG, "[%s] Completed data fetch of size %"PRId64", notifying caller", __FUNCTION__, bytes);
+    Debug(DEBUG_TAG, "[%s] Completed data fetch of size %" PRId64", notifying caller", __FUNCTION__, bytes);
     //InvokePlugin( TS_EVENT_INTERNAL_60200, (void *) client_response);
    client_bytes = bytes;
     //InvokePlugin( TS_EVENT_INTERNAL_60200, (void *) this);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/InkAPITest.cc
----------------------------------------------------------------------
diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index 046c126..51e352a 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -515,7 +515,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
 
     cache_vconn->read_vconnp = (TSVConn) data;
     content_length = TSVConnCacheObjectSizeGet(cache_vconn->read_vconnp);
-    Debug(UTDBG_TAG "_cache_read", "In cache open read [Content-Length: %"PRId64"]", content_length);
+    Debug(UTDBG_TAG "_cache_read", "In cache open read [Content-Length: %" PRId64"]", content_length);
     if (content_length != OBJECT_SIZE) {
       SDK_RPRINT(SDK_Cache_test, "TSVConnCacheObjectSizeGet", "TestCase1", TC_FAIL, "cached data size is incorrect");
 
@@ -566,7 +566,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
     nbytes = TSVIONBytesGet(cache_vconn->write_vio);
     ndone = TSVIONDoneGet(cache_vconn->write_vio);
     ntodo = TSVIONTodoGet(cache_vconn->write_vio);
-    Debug(UTDBG_TAG "_cache_write", "Nbytes=%"PRId64" Ndone=%"PRId64" Ntodo=%"PRId64"", nbytes, ndone, ntodo);
+    Debug(UTDBG_TAG "_cache_write", "Nbytes=%" PRId64" Ndone=%" PRId64" Ntodo=%" PRId64"", nbytes, ndone, ntodo);
 
     if (ndone == (OBJECT_SIZE / 2)) {
       TSVIONBytesSet(cache_vconn->write_vio, (OBJECT_SIZE - 100));
@@ -669,7 +669,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
     nbytes = TSVIONBytesGet(cache_vconn->write_vio);
     ndone = TSVIONDoneGet(cache_vconn->write_vio);
     ntodo = TSVIONTodoGet(cache_vconn->write_vio);
-    Debug(UTDBG_TAG "_cache_write", "Nbytes=%"PRId64" Ndone=%"PRId64" Ntodo=%"PRId64"", nbytes, ndone, ntodo);
+    Debug(UTDBG_TAG "_cache_write", "Nbytes=%" PRId64" Ndone=%" PRId64" Ntodo=%" PRId64"", nbytes, ndone, ntodo);
 
     TSVIOReenable(cache_vconn->write_vio);
     return 1;
@@ -687,7 +687,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
     nbytes = TSVIONBytesGet(cache_vconn->read_vio);
     ntodo = TSVIONTodoGet(cache_vconn->read_vio);
     ndone = TSVIONDoneGet(cache_vconn->read_vio);
-    Debug(UTDBG_TAG "_cache_read", "Nbytes=%"PRId64" Ndone=%"PRId64" Ntodo=%"PRId64"", nbytes, ndone, ntodo);
+    Debug(UTDBG_TAG "_cache_read", "Nbytes=%" PRId64" Ndone=%" PRId64" Ntodo=%" PRId64"", nbytes, ndone, ntodo);
 
     if (nbytes != (ndone + ntodo)) {
       SDK_RPRINT(SDK_Cache_test, "TSVIONBytesGet", "TestCase1", TC_FAIL, "read_vio corrupted");
@@ -734,7 +734,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
     nbytes = TSVIONBytesGet(cache_vconn->read_vio);
     ntodo = TSVIONTodoGet(cache_vconn->read_vio);
     ndone = TSVIONDoneGet(cache_vconn->read_vio);
-    Debug(UTDBG_TAG "_cache_read", "Nbytes=%"PRId64" Ndone=%"PRId64" Ntodo=%"PRId64"", nbytes, ndone, ntodo);
+    Debug(UTDBG_TAG "_cache_read", "Nbytes=%" PRId64" Ndone=%" PRId64" Ntodo=%" PRId64"", nbytes, ndone, ntodo);
 
     if (nbytes != (ndone + ntodo)) {
       SDK_RPRINT(SDK_Cache_test, "TSVIONBytesGet", "TestCase1", TC_FAIL, "read_vio corrupted");
@@ -753,7 +753,7 @@ cache_handler(TSCont contp, TSEvent event, void *data)
     // Fix for bug INKqa12276: Must consume data from iobuffer
     nbytes = TSIOBufferReaderAvail(cache_vconn->out_readerp);
     TSIOBufferReaderConsume(cache_vconn->out_readerp, nbytes);
-    TSDebug(UTDBG_TAG "_cache_read", "Consuming %"PRId64" bytes from cache read VC", nbytes);
+    TSDebug(UTDBG_TAG "_cache_read", "Consuming %" PRId64" bytes from cache read VC", nbytes);
 
     TSVIOReenable(cache_vconn->read_vio);
     Debug(UTDBG_TAG "_cache_read", "finishing up [j]");

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/InkAPITestTool.cc
----------------------------------------------------------------------
diff --git a/proxy/InkAPITestTool.cc b/proxy/InkAPITestTool.cc
index 0dcc087..91e3093 100644
--- a/proxy/InkAPITestTool.cc
+++ b/proxy/InkAPITestTool.cc
@@ -540,7 +540,7 @@ synclient_txn_read_response(TSCont contp)
       memcpy((char *) (txn->response + txn->response_len), blockptr, blocklen);
       txn->response_len += blocklen;
     } else {
-      TSError("Error: Response length %"PRId64" > response buffer size %d", txn->response_len+blocklen, RESPONSE_MAX_SIZE);
+      TSError("Error: Response length %" PRId64" > response buffer size %d", txn->response_len+blocklen, RESPONSE_MAX_SIZE);
     }
 
     block = TSIOBufferBlockNext(block);
@@ -571,7 +571,7 @@ synclient_txn_read_response_handler(TSCont contp, TSEvent event, void *data)
     }
 
     avail = TSIOBufferReaderAvail(txn->resp_reader);
-    TSDebug(CDBG_TAG, "%"PRId64" bytes available in buffer", avail);
+    TSDebug(CDBG_TAG, "%" PRId64" bytes available in buffer", avail);
 
     if (avail > 0) {
       synclient_txn_read_response(contp);
@@ -627,7 +627,7 @@ synclient_txn_write_request(TSCont contp)
   }
 
   /* Start writing the response */
-  TSDebug(CDBG_TAG, "Writing |%s| (%"PRId64") bytes", txn->request, len);
+  TSDebug(CDBG_TAG, "Writing |%s| (%" PRId64") bytes", txn->request, len);
   txn->write_vio = TSVConnWrite(txn->vconn, contp, txn->req_reader, len);
 
   return 1;
@@ -881,7 +881,7 @@ synserver_txn_write_response(TSCont contp)
   }
 
   /* Start writing the response */
-  TSDebug(SDBG_TAG, "Writing response: |%s| (%"PRId64") bytes)", response, len);
+  TSDebug(SDBG_TAG, "Writing response: |%s| (%" PRId64") bytes)", response, len);
   txn->write_vio = TSVConnWrite(txn->vconn, contp, txn->resp_reader, len);
 
   /* Now that response is in IOBuffer, free up response */
@@ -945,7 +945,7 @@ synserver_txn_read_request(TSCont contp)
       memcpy((char *) (txn->request + txn->request_len), blockptr, blocklen);
       txn->request_len += blocklen;
     } else {
-      TSError("Error: Request length %"PRId64" > request buffer size %d", txn->request_len+blocklen, REQUEST_MAX_SIZE);
+      TSError("Error: Request length %" PRId64" > request buffer size %d", txn->request_len+blocklen, REQUEST_MAX_SIZE);
     }
 
     block = TSIOBufferBlockNext(block);
@@ -975,7 +975,7 @@ synserver_txn_read_request_handler(TSCont contp, TSEvent event, void *data)
   case TS_EVENT_VCONN_READ_COMPLETE:
     TSDebug(SDBG_TAG, (event == TS_EVENT_VCONN_READ_READY) ? "READ_READY" : "READ_COMPLETE");
     avail = TSIOBufferReaderAvail(txn->req_reader);
-    TSDebug(SDBG_TAG, "%"PRId64" bytes available in buffer", avail);
+    TSDebug(SDBG_TAG, "%" PRId64" bytes available in buffer", avail);
 
     if (avail > 0) {
       end_of_request = synserver_txn_read_request(contp);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/PluginVC.cc
----------------------------------------------------------------------
diff --git a/proxy/PluginVC.cc b/proxy/PluginVC.cc
index 8df3262..52dfa26 100644
--- a/proxy/PluginVC.cc
+++ b/proxy/PluginVC.cc
@@ -244,7 +244,7 @@ PluginVC::do_io_read(Continuation * c, int64_t nbytes, MIOBuffer * buf)
   read_state.vio.vc_server = (VConnection *) this;
   read_state.vio.op = VIO::READ;
 
-  Debug("pvc", "[%u] %s: do_io_read for %"PRId64" bytes", PVC_ID, PVC_TYPE, nbytes);
+  Debug("pvc", "[%u] %s: do_io_read for %" PRId64" bytes", PVC_ID, PVC_TYPE, nbytes);
 
   // Since reentrant callbacks are not allowed on from do_io
   //   functions schedule ourselves get on a different stack
@@ -277,7 +277,7 @@ PluginVC::do_io_write(Continuation * c, int64_t nbytes, IOBufferReader * abuffer
   write_state.vio.vc_server = (VConnection *) this;
   write_state.vio.op = VIO::WRITE;
 
-  Debug("pvc", "[%u] %s: do_io_write for %"PRId64" bytes", PVC_ID, PVC_TYPE, nbytes);
+  Debug("pvc", "[%u] %s: do_io_write for %" PRId64" bytes", PVC_ID, PVC_TYPE, nbytes);
 
   // Since reentrant callbacks are not allowed on from do_io
   //   functions schedule ourselves get on a different stack
@@ -508,7 +508,7 @@ PluginVC::process_write_side(bool other_side_call)
   int64_t bytes_avail = reader->read_avail();
   int64_t act_on = MIN(bytes_avail, ntodo);
 
-  Debug("pvc", "[%u] %s: process_write_side; act_on %"PRId64"", PVC_ID, PVC_TYPE, act_on);
+  Debug("pvc", "[%u] %s: process_write_side; act_on %" PRId64"", PVC_ID, PVC_TYPE, act_on);
 
   if (other_side->closed || other_side->read_state.shutdown) {
     write_state.vio._cont->handleEvent(VC_EVENT_ERROR, &write_state.vio);
@@ -544,7 +544,7 @@ PluginVC::process_write_side(bool other_side_call)
 
   write_state.vio.ndone += added;
 
-  Debug("pvc", "[%u] %s: process_write_side; added %"PRId64"", PVC_ID, PVC_TYPE, added);
+  Debug("pvc", "[%u] %s: process_write_side; added %" PRId64"", PVC_ID, PVC_TYPE, added);
 
   if (write_state.vio.ntodo() == 0) {
     write_state.vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &write_state.vio);
@@ -623,7 +623,7 @@ PluginVC::process_read_side(bool other_side_call)
   int64_t bytes_avail = core_reader->read_avail();
   int64_t act_on = MIN(bytes_avail, ntodo);
 
-  Debug("pvc", "[%u] %s: process_read_side; act_on %"PRId64"", PVC_ID, PVC_TYPE, act_on);
+  Debug("pvc", "[%u] %s: process_read_side; act_on %" PRId64"", PVC_ID, PVC_TYPE, act_on);
 
   if (act_on <= 0) {
     if (other_side->closed || other_side->write_state.shutdown) {
@@ -656,7 +656,7 @@ PluginVC::process_read_side(bool other_side_call)
 
   read_state.vio.ndone += added;
 
-  Debug("pvc", "[%u] %s: process_read_side; added %"PRId64"", PVC_ID, PVC_TYPE, added);
+  Debug("pvc", "[%u] %s: process_read_side; added %" PRId64"", PVC_ID, PVC_TYPE, added);
 
   if (read_state.vio.ntodo() == 0) {
     read_state.vio._cont->handleEvent(VC_EVENT_READ_COMPLETE, &read_state.vio);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/Prefetch.cc
----------------------------------------------------------------------
diff --git a/proxy/Prefetch.cc b/proxy/Prefetch.cc
index 3812bb7..20bb84a 100644
--- a/proxy/Prefetch.cc
+++ b/proxy/Prefetch.cc
@@ -454,7 +454,7 @@ PrefetchTransform::handle_event(int event, void *edata)
 
   if (m_closed) {
     if (m_deletable) {
-      Debug("PrefetchParser", "PrefetchTransform free(): %"PRId64"", m_output_vio ? m_output_vio->ndone : 0);
+      Debug("PrefetchParser", "PrefetchTransform free(): %" PRId64"", m_output_vio ? m_output_vio->ndone : 0);
       if (m_output_buf) {
         free_MIOBuffer(m_output_buf);
         m_output_buf = 0;
@@ -518,7 +518,7 @@ PrefetchTransform::handle_event(int event, void *edata)
           }
 
           if (towrite > 0) {
-            Debug("PrefetchParser", "handle_event() " "writing %"PRId64" bytes to output", towrite);
+            Debug("PrefetchParser", "handle_event() " "writing %" PRId64" bytes to output", towrite);
 
             //Debug("PrefetchParser", "Read avail before = %d\n", avail);
 
@@ -1682,7 +1682,7 @@ PrefetchBlaster::bufferObject(int event, void *data)
   case VC_EVENT_READ_READY:
     if (buf->high_water()) {
       //right now we don't handle DEL events on the child
-      Debug("PrefetchBlasterTemp", "The object is bigger than %"PRId64" bytes " "cancelling the url", buf->water_mark);
+      Debug("PrefetchBlasterTemp", "The object is bigger than %" PRId64" bytes " "cancelling the url", buf->water_mark);
       buf->reset();
       buf->fill(PRELOAD_HEADER_LEN);
       buf->write("DEL ", 4);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/StatSystem.cc
----------------------------------------------------------------------
diff --git a/proxy/StatSystem.cc b/proxy/StatSystem.cc
index e53617c..480dfc9 100644
--- a/proxy/StatSystem.cc
+++ b/proxy/StatSystem.cc
@@ -362,7 +362,7 @@ take_rusage_snap()
       rusage_snap_time = ink_get_hrtime();
     break;
   }
-  Debug("rusage", "took rusage snap %"PRId64"", rusage_snap_time);
+  Debug("rusage", "took rusage snap %" PRId64"", rusage_snap_time);
 }
 
 struct SnapCont;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/Transform.cc
----------------------------------------------------------------------
diff --git a/proxy/Transform.cc b/proxy/Transform.cc
index 7bf0cf4..8674c33 100644
--- a/proxy/Transform.cc
+++ b/proxy/Transform.cc
@@ -614,7 +614,7 @@ NullTransform::handle_event(int event, void *edata)
 
   if (m_closed) {
     if (m_deletable) {
-      Debug("transform", "NullTransform destroy: %"PRId64" [%p]", m_output_vio ? m_output_vio->ndone : 0, this);
+      Debug("transform", "NullTransform destroy: %" PRId64" [%p]", m_output_vio ? m_output_vio->ndone : 0, this);
       delete this;
     }
   } else {
@@ -670,7 +670,7 @@ NullTransform::handle_event(int event, void *edata)
           }
 
           if (towrite > 0) {
-            Debug("transform", "[NullTransform::handle_event] " "writing %"PRId64" bytes to output", towrite);
+            Debug("transform", "[NullTransform::handle_event] " "writing %" PRId64" bytes to output", towrite);
             m_output_buf->write(m_write_vio.get_reader(), towrite);
 
             m_write_vio.get_reader()->consume(towrite);
@@ -767,7 +767,7 @@ RangeTransform::handle_event(int event, void *edata)
 
   if (m_closed) {
     if (m_deletable) {
-      Debug("http_trans", "RangeTransform destroy: %p ndone=%"PRId64, this, m_output_vio ? m_output_vio->ndone : 0);
+      Debug("http_trans", "RangeTransform destroy: %p ndone=%" PRId64, this, m_output_vio ? m_output_vio->ndone : 0);
       delete this;
     }
   } else {
@@ -879,7 +879,7 @@ RangeTransform::transform_to_range()
           add_boundary(true);
         }
 
-        Debug("http_trans", "total bytes of Range response body is %"PRId64, m_done);
+        Debug("http_trans", "total bytes of Range response body is %" PRId64, m_done);
         m_output_vio->nbytes = m_done;
         m_output_vio->reenable();
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/Update.cc
----------------------------------------------------------------------
diff --git a/proxy/Update.cc b/proxy/Update.cc
index 56ef1b6..fb7d089 100644
--- a/proxy/Update.cc
+++ b/proxy/Update.cc
@@ -769,8 +769,8 @@ UpdateConfigManager::init()
   UPDATE_CLEAR_DYN_STAT(update_state_machines_stat);
 
   Debug("update",
-        "Update params: enable %"PRId64" force %"PRId64" rcnt %"PRId64" rint %"PRId64" updates %"PRId64" "
-        "max_sm %"PRId64" mem %"PRId64"",
+        "Update params: enable %" PRId64" force %" PRId64" rcnt %" PRId64" rint %" PRId64" updates %" PRId64" "
+        "max_sm %" PRId64" mem %" PRId64"",
         _CP_actual->_enabled, _CP_actual->_immediate_update,
         _CP_actual->_retry_count, _CP_actual->_retry_interval,
         _CP_actual->_concurrent_updates, _CP_actual->_max_update_state_machines, _CP_actual->_memory_use_in_mb);
@@ -862,7 +862,7 @@ UpdateConfigManager::ProcessUpdate(int event, Event * e)
 
     if (!(*_CP == *p)) {
       _CP = p;
-      Debug("update", "enable %"PRId64" force %"PRId64" rcnt %"PRId64" rint %"PRId64" updates %"PRId64" state machines %"PRId64" mem %"PRId64"",
+      Debug("update", "enable %" PRId64" force %" PRId64" rcnt %" PRId64" rint %" PRId64" updates %" PRId64" state machines %" PRId64" mem %" PRId64"",
             p->_enabled, p->_immediate_update, p->_retry_count,
             p->_retry_interval, p->_concurrent_updates, p->_max_update_state_machines, p->_memory_use_in_mb);
     } else {

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpBodyFactory.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpBodyFactory.cc b/proxy/http/HttpBodyFactory.cc
index 8c11a27..b425dfb 100644
--- a/proxy/http/HttpBodyFactory.cc
+++ b/proxy/http/HttpBodyFactory.cc
@@ -288,17 +288,17 @@ HttpBodyFactory::reconfigure()
   rec_err = RecGetRecordInt("proxy.config.body_factory.enable_customizations", &e);
   enable_customizations = ((rec_err == REC_ERR_OKAY) ? e : 0);
   all_found = all_found && (rec_err == REC_ERR_OKAY);
-  Debug("body_factory", "enable_customizations = %d (found = %"PRId64")", enable_customizations, e);
+  Debug("body_factory", "enable_customizations = %d (found = %" PRId64")", enable_customizations, e);
 
   rec_err = RecGetRecordInt("proxy.config.body_factory.enable_logging", &e);
   enable_logging = ((rec_err == REC_ERR_OKAY) ? (e ? true : false) : false);
   all_found = all_found && (rec_err == REC_ERR_OKAY);
-  Debug("body_factory", "enable_logging = %d (found = %"PRId64")", enable_logging, e);
+  Debug("body_factory", "enable_logging = %d (found = %" PRId64")", enable_logging, e);
 
   rec_err = RecGetRecordInt("proxy.config.body_factory.response_suppression_mode", &e);
   response_suppression_mode = ((rec_err == REC_ERR_OKAY) ? e : 0);
   all_found = all_found && (rec_err == REC_ERR_OKAY);
-  Debug("body_factory", "response_suppression_mode = %d (found = %"PRId64")", response_suppression_mode, e);
+  Debug("body_factory", "response_suppression_mode = %d (found = %" PRId64")", response_suppression_mode, e);
 
   rec_err = RecGetRecordString_Xmalloc("proxy.config.body_factory.template_sets_dir", &s);
   all_found = all_found && (rec_err == REC_ERR_OKAY);
@@ -316,7 +316,7 @@ HttpBodyFactory::reconfigure()
     }
   }
 
-  Debug("body_factory", "directory_of_template_sets = '%s' (found = %"PRId64")", directory_of_template_sets, e);
+  Debug("body_factory", "directory_of_template_sets = '%s' (found = %" PRId64")", directory_of_template_sets, e);
 
   if (!all_found) {
     Warning("config changed, but can't fetch all proxy.config.body_factory values");
@@ -496,7 +496,7 @@ HttpBodyFactory::find_template(const char *set, const char *type, HttpBodySet **
         return (NULL);
       *body_set_return = body_set;
 
-      Debug("body_factory", "find_template(%s,%s) -> (file %s, length %"PRId64", lang '%s', charset '%s')",
+      Debug("body_factory", "find_template(%s,%s) -> (file %s, length %" PRId64", lang '%s', charset '%s')",
             set, type, t->template_pathname, t->byte_count, body_set->content_language, body_set->content_charset);
 
       return (t);
@@ -892,7 +892,7 @@ HttpBodySet::get_template_by_name(const char *name)
     HttpBodyTemplate *t = (HttpBodyTemplate *) v;
     if ((t == NULL) || (!t->is_sane()))
       return (NULL);
-    Debug("body_factory", "    get_template_by_name(%s) -> (file %s, length %"PRId64")",
+    Debug("body_factory", "    get_template_by_name(%s) -> (file %s, length %" PRId64")",
           name, t->template_pathname, t->byte_count);
     return (t);
   }
@@ -984,13 +984,13 @@ HttpBodyTemplate::load_from_file(char *dir, char *file)
   ///////////////////////////
 
   if (bytes_read != new_byte_count) {
-    Warning("reading template file '%s', got %"PRId64" bytes instead of %"PRId64" (%s)",
+    Warning("reading template file '%s', got %" PRId64" bytes instead of %" PRId64" (%s)",
             path, bytes_read, new_byte_count, (strerror(errno) ? strerror(errno) : "unknown error"));
     ats_free(new_template_buffer);
     return (0);
   }
 
-  Debug("body_factory", "    read %"PRId64" bytes from '%s'", new_byte_count, path);
+  Debug("body_factory", "    read %" PRId64" bytes from '%s'", new_byte_count, path);
 
   /////////////////////////////////
   // actually commit the changes //
@@ -1020,7 +1020,7 @@ HttpBodyTemplate::build_instantiated_buffer(HttpTransact::State * context, int64
   *buflen_return = ((buffer == NULL) ? 0 : strlen(buffer));
   Debug("body_factory_instantiation", "    after instantiation: [%s]", buffer);
 
-  Debug("body_factory", "  returning %"PRId64" byte instantiated buffer", *buflen_return);
+  Debug("body_factory", "  returning %" PRId64" byte instantiated buffer", *buflen_return);
 #endif
   return (buffer);
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpClientSession.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpClientSession.cc b/proxy/http/HttpClientSession.cc
index 7ca304c..6e5dd1e 100644
--- a/proxy/http/HttpClientSession.cc
+++ b/proxy/http/HttpClientSession.cc
@@ -152,7 +152,7 @@ HttpClientSession::new_transaction()
   /////////////////////////
   // set up timeouts     //
   /////////////////////////
-  DebugSsn("http_cs", "[%" PRId64 "] using accept inactivity timeout [%"PRId64" seconds]",
+  DebugSsn("http_cs", "[%" PRId64 "] using accept inactivity timeout [%" PRId64" seconds]",
         con_id, HttpConfig::m_master.accept_no_activity_timeout);
   client_vc->set_inactivity_timeout(HRTIME_SECONDS(HttpConfig::m_master.accept_no_activity_timeout));
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpConfig.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpConfig.cc b/proxy/http/HttpConfig.cc
index e56207a..3273d89 100644
--- a/proxy/http/HttpConfig.cc
+++ b/proxy/http/HttpConfig.cc
@@ -1619,9 +1619,9 @@ HttpConfig::reconfigure()
 
 // Redirection debug statements
   Debug("http_init", "proxy.config.http.redirection_enabled = %d", params->redirection_enabled);
-  Debug("http_init", "proxy.config.http.number_of_redirections = %"PRId64"", params->number_of_redirections);
+  Debug("http_init", "proxy.config.http.number_of_redirections = %" PRId64"", params->number_of_redirections);
 
-  Debug("http_init", "proxy.config.http.post_copy_size = %"PRId64"", params->post_copy_size);
+  Debug("http_init", "proxy.config.http.post_copy_size = %" PRId64"", params->post_copy_size);
 }
 
 ////////////////////////////////////////////////////////////////

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpSM.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index 02f1526..c7deff1 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -1623,7 +1623,7 @@ HttpSM::state_http_server_open(int event, void *data)
     // the connection count.
     if (t_state.txn_conf->origin_max_connections > 0 ||
         t_state.http_config_param->origin_min_keep_alive_connections > 0) {
-      DebugSM("http_ss", "[%" PRId64 "] max number of connections: %"PRIu64, sm_id, t_state.txn_conf->origin_max_connections);
+      DebugSM("http_ss", "[%" PRId64 "] max number of connections: %" PRIu64, sm_id, t_state.txn_conf->origin_max_connections);
       session->enable_origin_connection_limiting = true;
     }
     /*UnixNetVConnection * vc = (UnixNetVConnection*)(ua_session->client_vc);
@@ -2700,7 +2700,7 @@ HttpSM::is_http_server_eos_truncation(HttpTunnelProducer * p)
   int64_t cl = t_state.hdr_info.server_response.get_content_length();
 
   if (cl != UNDEFINED_COUNT && cl > server_response_body_bytes) {
-    DebugSM("http", "[%" PRId64 "] server eos after %"PRId64".  Expected %"PRId64, sm_id, cl, server_response_body_bytes);
+    DebugSM("http", "[%" PRId64 "] server eos after %" PRId64".  Expected %" PRId64, sm_id, cl, server_response_body_bytes);
     return true;
   } else {
     return false;
@@ -4037,7 +4037,7 @@ HttpSM::calculate_output_cl(int64_t content_length, int64_t num_chars)
     t_state.range_output_cl += boundary_size + 2;
   }
 
-  Debug("http_range", "Pre-calculated Content-Length for Range response is %"PRId64, t_state.range_output_cl);
+  Debug("http_range", "Pre-calculated Content-Length for Range response is %" PRId64, t_state.range_output_cl);
 }
 
 void
@@ -5441,7 +5441,7 @@ HttpSM::setup_server_send_request()
 
   // the plugin decided to append a message to the request
   if (api_set) {
-    DebugSM("http", "[%" PRId64 "] appending msg of %"PRId64" bytes to request %s", sm_id, msg_len, t_state.internal_msg_buffer);
+    DebugSM("http", "[%" PRId64 "] appending msg of %" PRId64" bytes to request %s", sm_id, msg_len, t_state.internal_msg_buffer);
     hdr_length += server_entry->write_buffer->write(t_state.internal_msg_buffer, msg_len);
     server_request_body_bytes = msg_len;
   }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpTransact.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTransact.cc b/proxy/http/HttpTransact.cc
index 00779f0..b47a65d 100644
--- a/proxy/http/HttpTransact.cc
+++ b/proxy/http/HttpTransact.cc
@@ -1403,7 +1403,7 @@ HttpTransact::PPDNSLookup(State* s)
     s->parent_info.dns_round_robin = s->dns_info.round_robin;
 
     char addrbuf[INET6_ADDRSTRLEN];
-    DebugTxn("http_trans", "[PPDNSLookup] DNS lookup for sm_id[%"PRId64"] successful IP: %s",
+    DebugTxn("http_trans", "[PPDNSLookup] DNS lookup for sm_id[%" PRId64"] successful IP: %s",
           s->state_machine->sm_id, ats_ip_ntop(&s->parent_info.addr.sa, addrbuf, sizeof(addrbuf)));
   }
 
@@ -3377,7 +3377,7 @@ HttpTransact::handle_response_from_parent(State* s)
         if ((s->current.attempts - 1) % s->http_config_param->per_parent_connect_attempts != 0) {
           // No we are not done with this parent so retry
           s->next_action = how_to_open_connection(s);
-          DebugTxn("http_trans", "%s Retrying parent for attempt %d, max %"PRId64,
+          DebugTxn("http_trans", "%s Retrying parent for attempt %d, max %" PRId64,
                 "[handle_response_from_parent]", s->current.attempts, s->http_config_param->per_parent_connect_attempts);
           return;
         } else {
@@ -5659,7 +5659,7 @@ HttpTransact::initialize_state_variables_from_request(State* s, HTTPHdr* obsolet
     int64_t length = incoming_request->get_content_length();
     s->hdr_info.request_content_length = (length >= 0) ? length : HTTP_UNDEFINED_CL;    // content length less than zero is invalid
 
-    DebugTxn("http_trans", "[init_stat_vars_from_req] set req cont length to %"PRId64,
+    DebugTxn("http_trans", "[init_stat_vars_from_req] set req cont length to %" PRId64,
           s->hdr_info.request_content_length);
 
   } else {
@@ -6748,7 +6748,7 @@ HttpTransact::handle_content_length_header(State* s, HTTPHdr* header, HTTPHdr* b
         header->field_delete(MIME_FIELD_CONTENT_LENGTH, MIME_LEN_CONTENT_LENGTH);
         s->hdr_info.trust_response_cl = false;
       }
-      Debug("http_trans", "[handle_content_length_header] RESPONSE cont len in hdr is %"PRId64, header->get_content_length());
+      Debug("http_trans", "[handle_content_length_header] RESPONSE cont len in hdr is %" PRId64, header->get_content_length());
     } else {
       // No content length header
       if (s->source == SOURCE_CACHE) {
@@ -6810,7 +6810,7 @@ HttpTransact::handle_content_length_header(State* s, HTTPHdr* header, HTTPHdr* b
       header->field_delete(MIME_FIELD_CONTENT_LENGTH, MIME_LEN_CONTENT_LENGTH);
       s->hdr_info.request_content_length = HTTP_UNDEFINED_CL;
     }
-    DebugTxn("http_trans", "[handle_content_length_header] cont len in hdr is %"PRId64", stat var is %"PRId64,
+    DebugTxn("http_trans", "[handle_content_length_header] cont len in hdr is %" PRId64", stat var is %" PRId64,
           header->get_content_length(), s->hdr_info.request_content_length);
   }
 
@@ -8921,7 +8921,7 @@ HttpTransact::change_response_header_because_of_range_request(State *s, HTTPHdr
     char numbers[RANGE_NUMBERS_LENGTH];
 
     field = header->field_create(MIME_FIELD_CONTENT_RANGE, MIME_LEN_CONTENT_RANGE);
-    snprintf(numbers, sizeof(numbers), "bytes %"PRId64"-%"PRId64"/%"PRId64, s->ranges[0]._start, s->ranges[0]._end, s->cache_info.object_read->object_size_get());
+    snprintf(numbers, sizeof(numbers), "bytes %" PRId64"-%" PRId64"/%" PRId64, s->ranges[0]._start, s->ranges[0]._end, s->cache_info.object_read->object_size_get());
     field->value_append(header->m_heap, header->m_mime, numbers, strlen(numbers));
     header->field_attach(field);
     header->set_content_length(s->range_output_cl);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/http/HttpTunnel.cc
----------------------------------------------------------------------
diff --git a/proxy/http/HttpTunnel.cc b/proxy/http/HttpTunnel.cc
index c3c8af5..d468845 100644
--- a/proxy/http/HttpTunnel.cc
+++ b/proxy/http/HttpTunnel.cc
@@ -41,7 +41,7 @@
 static const int max_chunked_ahead_bytes = 1 << 15;
 static const int max_chunked_ahead_blocks = 128;
 static const int min_block_transfer_bytes = 256;
-static char const * const CHUNK_HEADER_FMT = "%"PRIx64"\r\n";
+static char const * const CHUNK_HEADER_FMT = "%" PRIx64"\r\n";
 // This should be as small as possible because it will only hold the
 // header and trailer per chunk - the chunk body will be a reference to
 // a block in the input stream.
@@ -284,7 +284,7 @@ ChunkedHandler::read_chunk()
 
   ink_assert(bytes_left >= 0);
   if (bytes_left == 0) {
-    Debug("http_chunk", "completed read of chunk of %"PRId64" bytes", cur_chunk_size);
+    Debug("http_chunk", "completed read of chunk of %" PRId64" bytes", cur_chunk_size);
 
     // Check to see if we need to flow control the output
     if (dechunked_buffer &&
@@ -296,7 +296,7 @@ ChunkedHandler::read_chunk()
       state = CHUNK_READ_SIZE_START;
     }
   } else if (bytes_left > 0) {
-    Debug("http_chunk", "read %"PRId64" bytes of an %"PRId64" chunk", b, cur_chunk_size);
+    Debug("http_chunk", "read %" PRId64" bytes of an %" PRId64" chunk", b, cur_chunk_size);
   }
 }
 
@@ -402,7 +402,7 @@ bool ChunkedHandler::generate_chunked_content()
       return false;
     } else {
       state = CHUNK_WRITE_CHUNK;
-      Debug("http_chunk", "creating a chunk of size %"PRId64" bytes", write_val);
+      Debug("http_chunk", "creating a chunk of size %" PRId64" bytes", write_val);
 
       // Output the chunk size.
       if (write_val != max_chunk_size) {
@@ -781,7 +781,7 @@ HttpTunnel::producer_run(HttpTunnelProducer * p)
     } else if (p->do_dechunking) {
       // bz57413
       Debug("http_tunnel",
-            "[producer_run] do_dechunking p->chunked_handler.chunked_reader->read_avail() = %"PRId64"",
+            "[producer_run] do_dechunking p->chunked_handler.chunked_reader->read_avail() = %" PRId64"",
             p->chunked_handler.chunked_reader->read_avail());
 
       // initialize a reader to dechunked buffer start before writing to keep ref count
@@ -792,7 +792,7 @@ HttpTunnel::producer_run(HttpTunnelProducer * p)
       if (!transform_consumer) {
         p->chunked_handler.dechunked_buffer->write(p->buffer_start, p->chunked_handler.skip_bytes);
 
-        Debug("http_tunnel", "[producer_run] do_dechunking::Copied header of size %"PRId64"", p->chunked_handler.skip_bytes);
+        Debug("http_tunnel", "[producer_run] do_dechunking::Copied header of size %" PRId64"", p->chunked_handler.skip_bytes);
       }
     }
   }
@@ -878,12 +878,12 @@ HttpTunnel::producer_run(HttpTunnelProducer * p)
   // including the maximum configured post data size
   if (p->alive && sm->t_state.method == HTTP_WKSIDX_POST && sm->enable_redirection
       && sm->redirection_tries == 0 && (p->vc_type == HT_HTTP_CLIENT)) {
-    Debug("http_redirect", "[HttpTunnel::producer_run] client post: %"PRId64" max size: %"PRId64"",
+    Debug("http_redirect", "[HttpTunnel::producer_run] client post: %" PRId64" max size: %" PRId64"",
           p->buffer_start->read_avail(), HttpConfig::m_master.post_copy_size);
 
     // (note that since we are not dechunking POST, this is the chunked size if chunked)
     if (p->buffer_start->read_avail() > HttpConfig::m_master.post_copy_size) {
-      Debug("http_redirect", "[HttpTunnel::producer_handler] post exceeds buffer limit, buffer_avail=%"PRId64" limit=%"PRId64"",
+      Debug("http_redirect", "[HttpTunnel::producer_handler] post exceeds buffer limit, buffer_avail=%" PRId64" limit=%" PRId64"",
             p->buffer_start->read_avail(), HttpConfig::m_master.post_copy_size);
       sm->enable_redirection = false;
     } else {
@@ -909,11 +909,11 @@ HttpTunnel::producer_run(HttpTunnelProducer * p)
     // bz57413
     // If there is no transformation plugin, then we didn't add the header, hence no need to consume it
     Debug("http_tunnel",
-          "[producer_run] do_dechunking p->chunked_handler.chunked_reader->read_avail() = %"PRId64"",
+          "[producer_run] do_dechunking p->chunked_handler.chunked_reader->read_avail() = %" PRId64"",
           p->chunked_handler.chunked_reader->read_avail());
     if (!transform_consumer && (p->chunked_handler.chunked_reader->read_avail() >= p->chunked_handler.skip_bytes)) {
       p->chunked_handler.chunked_reader->consume(p->chunked_handler.skip_bytes);
-      Debug("http_tunnel", "[producer_run] do_dechunking p->chunked_handler.skip_bytes = %"PRId64"",
+      Debug("http_tunnel", "[producer_run] do_dechunking p->chunked_handler.skip_bytes = %" PRId64"",
             p->chunked_handler.skip_bytes);
     }
     //if(p->chunked_handler.chunked_reader->read_avail() > 0)
@@ -1096,7 +1096,7 @@ bool HttpTunnel::producer_handler(int event, HttpTunnelProducer * p)
     if ((postbuf->postdata_copy_buffer_start->read_avail() + postbuf->ua_buffer_reader->read_avail())
         > HttpConfig::m_master.post_copy_size) {
       Debug("http_redirect",
-            "[HttpTunnel::producer_handler] post exceeds buffer limit, buffer_avail=%"PRId64" reader_avail=%"PRId64" limit=%"PRId64"",
+            "[HttpTunnel::producer_handler] post exceeds buffer limit, buffer_avail=%" PRId64" reader_avail=%" PRId64" limit=%" PRId64"",
             postbuf->postdata_copy_buffer_start->read_avail(), postbuf->ua_buffer_reader->read_avail(),
             HttpConfig::m_master.post_copy_size);
       deallocate_redirect_postdata_buffers();
@@ -1523,7 +1523,7 @@ void
 HttpTunnel::copy_partial_post_data()
 {
   postbuf->postdata_copy_buffer->write(postbuf->ua_buffer_reader);
-  Debug("http_redirect", "[HttpTunnel::copy_partial_post_data] wrote %"PRId64" bytes to buffers %"PRId64"",
+  Debug("http_redirect", "[HttpTunnel::copy_partial_post_data] wrote %" PRId64" bytes to buffers %" PRId64"",
         postbuf->ua_buffer_reader->read_avail(), postbuf->postdata_copy_buffer_start->read_avail());
   postbuf->ua_buffer_reader->consume(postbuf->ua_buffer_reader->read_avail());
 }

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/logging/LogCollationHostSM.cc
----------------------------------------------------------------------
diff --git a/proxy/logging/LogCollationHostSM.cc b/proxy/logging/LogCollationHostSM.cc
index dab1f4e..ea808e1 100644
--- a/proxy/logging/LogCollationHostSM.cc
+++ b/proxy/logging/LogCollationHostSM.cc
@@ -400,7 +400,7 @@ LogCollationHostSM::read_hdr(int event, VIO * vio)
     m_read_bytes_received = 0;
     m_read_buffer = (char *) &m_net_msg_header;
     ink_assert(m_client_vc != NULL);
-    Debug("log-coll", "[%d]host:read_hdr - do_io_read(%"PRId64")", m_id, m_read_bytes_wanted);
+    Debug("log-coll", "[%d]host:read_hdr - do_io_read(%" PRId64")", m_id, m_read_bytes_wanted);
     m_client_vio = m_client_vc->do_io_read(this, m_read_bytes_wanted, m_client_buffer);
     ink_assert(m_client_vio != NULL);
     return EVENT_CONT;
@@ -456,7 +456,7 @@ LogCollationHostSM::read_body(int event, VIO * vio)
     m_read_buffer = new char[m_read_bytes_wanted];
     ink_assert(m_read_buffer != NULL);
     ink_assert(m_client_vc != NULL);
-    Debug("log-coll", "[%d]host:read_body - do_io_read(%"PRId64")", m_id, m_read_bytes_wanted);
+    Debug("log-coll", "[%d]host:read_body - do_io_read(%" PRId64")", m_id, m_read_bytes_wanted);
     m_client_vio = m_client_vc->do_io_read(this, m_read_bytes_wanted, m_client_buffer);
     ink_assert(m_client_vio != NULL);
     return EVENT_CONT;

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/proxy/logging/LogField.cc
----------------------------------------------------------------------
diff --git a/proxy/logging/LogField.cc b/proxy/logging/LogField.cc
index f3fbc52..09ca09b 100644
--- a/proxy/logging/LogField.cc
+++ b/proxy/logging/LogField.cc
@@ -380,8 +380,8 @@ LogField::update_aggregate(int64_t val)
     return;
   }
 
-  Debug("log-agg", "Aggregate field %s updated with val %"PRId64", "
-        "new val = %"PRId64", cnt = %"PRId64"", m_symbol, val, m_agg_val, m_agg_cnt);
+  Debug("log-agg", "Aggregate field %s updated with val %" PRId64", "
+        "new val = %" PRId64", cnt = %" PRId64"", m_symbol, val, m_agg_val, m_agg_cnt);
 }
 
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/b216afa3/tools/jtest/jtest.cc
----------------------------------------------------------------------
diff --git a/tools/jtest/jtest.cc b/tools/jtest/jtest.cc
index 7ea6859..da7236a 100644
--- a/tools/jtest/jtest.cc
+++ b/tools/jtest/jtest.cc
@@ -2876,7 +2876,7 @@ void interval_report() {
   RUNNING(tbytes);
   float t = (float)(now - start_time);
   uint64_t per = current_clients ? running_cbytes / current_clients : 0;
-  printf("%4d %4d %7.1f %4d %4d %10"PRIu64"/%-6"PRIu64"  %4d %4d %4d  %9"PRIu64" %6.1f %4d\n",
+  printf("%4d %4d %7.1f %4d %4d %10" PRIu64"/%-6" PRIu64"  %4d %4d %4d  %9" PRIu64" %6.1f %4d\n",
          current_clients, // clients, n_ka_cache,
          running_clients,
          running_ops, running_b1latency, running_latency,
@@ -2887,15 +2887,15 @@ void interval_report() {
          t/((float)HRTIME_SECOND),
          errors);
   if (is_done()) {
-    printf("Total Client Request Bytes:\t\t%"PRIu64"\n", total_client_request_bytes);
-    printf("Total Server Response Header Bytes:\t%"PRIu64"\n",
+    printf("Total Client Request Bytes:\t\t%" PRIu64"\n", total_client_request_bytes);
+    printf("Total Server Response Header Bytes:\t%" PRIu64"\n",
            total_server_response_header_bytes);
-    printf("Total Server Response Body Bytes:\t%"PRIu64"\n",
+    printf("Total Server Response Body Bytes:\t%" PRIu64"\n",
            total_server_response_body_bytes);
-    printf("Total Proxy Request Bytes:\t\t%"PRIu64"\n", total_proxy_request_bytes);
-    printf("Total Proxy Response Header Bytes:\t%"PRIu64"\n",
+    printf("Total Proxy Request Bytes:\t\t%" PRIu64"\n", total_proxy_request_bytes);
+    printf("Total Proxy Response Header Bytes:\t%" PRIu64"\n",
            total_proxy_response_header_bytes);
-    printf("Total Proxy Response Body Bytes:\t%"PRIu64"\n",
+    printf("Total Proxy Response Body Bytes:\t%" PRIu64"\n",
            total_proxy_response_body_bytes);
   }
 }
@@ -4565,9 +4565,9 @@ void show_argument_configuration(ArgumentDescription * argument_descriptions,
         break;
       case 'L':
 #if defined(FreeBSD)
-        printf("%"PRId64"",*(int64_t*)argument_descriptions[i].location);
+        printf("%" PRId64"",*(int64_t*)argument_descriptions[i].location);
 #else
-        printf("%"PRId64"",*(int64_t*)argument_descriptions[i].location);
+        printf("%" PRId64"",*(int64_t*)argument_descriptions[i].location);
 #endif
         break;
       case 'S':
@@ -4671,9 +4671,9 @@ void usage(ArgumentDescription * argument_descriptions,
       case 'L':
         fprintf(stderr, 
 #if defined(FreeBSD)
-                " %-9"PRId64"",
+                " %-9" PRId64"",
 #else
-                " %-9"PRId64"",
+                " %-9" PRId64"",
 #endif
                 *(int64_t*)argument_descriptions[i].location);
         break;


Re: std=c++11 breaks trunk, what now?

Posted by Leif Hedstrom <zw...@apache.org>.
On 11/23/12 10:13 AM, ming.zym@gmail.com wrote:
> 'why mt ats is crashing', I have to tell them:
> 1, do not enable Range in v3.2.0

Right, fixed on trunk I assume / hope?

> 2, do not use the CLFUS, use the standard LRU

What is the issue here? Are there bugs filed for this? If CLFUS is 
crashing, we should fix it (and/or perhaps change the default).

> 3, do not use the thread pool to manage server sessions

If I recall, this is something with the cluster interaction with the 
sessions? What are the bug ID's here? For most users, the above is bad 
advice IMO. If you don't use cache clustering, the per thread pools of 
server sessions is vastly superior (by 1 magnitude or more).

Cheers,

-- leif


Re: std=c++11 breaks trunk, what now?

Posted by "ming.zym@gmail.com" <mi...@gmail.com>.
personally, I am trying to make the master tree as clean as possible, a
clean tree is very important for new comers, when they can feel happy
with the way we pushing the project, I'd like every one love this
project, for using and coding everyday.

Well, we make big changes when it really ought to, but that should not
turn into "do what ever you want at anytime". That is why we call us a
community and a community project, I really wish we can work as a team,
even we don't know each other "face to face". We work for fun, we need
feel nice with the codes, and the man behind the codes :D

Big project as ATS, I think no none is able to all the parts, we believe
that we can work together so we can manage the big ship.

For ATS project, I always think that we don't need run in a hurry, we
are the most powerful system in the world, no one is able to kill us in
this field, we have a big & healthy community support, what we aught to
do is make it better in stabilization & performance, we are high
performance critical system that we can even persuade the user choose
the right hardware and operation system as we suggest, just "because it
sucks less!"

I am managing the small community in China, where I was always asked by
'why mt ats is crashing', I have to tell them:
1, do not enable Range in v3.2.0
2, do not use the CLFUS, use the standard LRU
3, do not use the thread pool to manage server sessions
......

at last, try my tree if you are not satisfied with the official tree, it
is proved to be working well with 10 thousands of queries per second.

I am not happy with that, because I working for the community, just
because we can not control the quality of our official releases.

The quality is build from everyday coding, everyone thinking. we really
should care of it.

fin, I have wrote too much, that don't like me as common. I'd wish my
words not hurt anyone here.

thanks, you are my best partner!

在 2012-11-22四的 11:26 -0500,Leif Hedstrom写道:
> On 11/21/12 12:35 PM, James Peach wrote:
> > On 21/11/2012, at 9:32 AM, James Peach <jp...@apache.org> wrote:
> >
> >>
> >> This change makes merging "upstream" changes for him much more
> >> difficult. Before I revert this commit again, I'd like to
> >> bring this to attention, because:
> >>
> >>    trunk is CTR, and I'd like to keep it that way.
> >>
> >> There's a number of options we have from here, and I'd really
> >> like we figure this out now.
> >> Obviously I did not test this on GCC 4.7 like I should have.
> > Oh, and when people (like me) commit breaking changes like this we should feel comfortable with just reverting them IMHO ...
> 
> Yeah, I think we should nuke it for now.
> 
> A big change, such as changing which C++ standard we conform to in our 
> builds, ought to be discussed on the mailing lists I think? I know we 
> made it configure optional, and that's fine, but apparently there are 
> serious side effects :).
> 
> Cheers,
> 
> -- Leif
> 
> 
> 

-- 
Zhao Yongming
aka: zym @ apache.org, yonghao @ taobao.com


Re: std=c++11 breaks trunk, what now?

Posted by Leif Hedstrom <zw...@apache.org>.
On 11/21/12 12:35 PM, James Peach wrote:
> On 21/11/2012, at 9:32 AM, James Peach <jp...@apache.org> wrote:
>
>>
>> This change makes merging "upstream" changes for him much more
>> difficult. Before I revert this commit again, I'd like to
>> bring this to attention, because:
>>
>>    trunk is CTR, and I'd like to keep it that way.
>>
>> There's a number of options we have from here, and I'd really
>> like we figure this out now.
>> Obviously I did not test this on GCC 4.7 like I should have.
> Oh, and when people (like me) commit breaking changes like this we should feel comfortable with just reverting them IMHO ...

Yeah, I think we should nuke it for now.

A big change, such as changing which C++ standard we conform to in our 
builds, ought to be discussed on the mailing lists I think? I know we 
made it configure optional, and that's fine, but apparently there are 
serious side effects :).

Cheers,

-- Leif




Re: std=c++11 breaks trunk, what now?

Posted by James Peach <jp...@apache.org>.
On 21/11/2012, at 9:32 AM, James Peach <jp...@apache.org> wrote:

> On 21/11/2012, at 9:27 AM, Igor Galić <i....@brainsware.org> wrote:
> 
>> 
>> Hey folks,
>> 
>> regarding this MASSIVE change:
>> 
>>> TS-1582 space between string and format specifiers
>>> 
>>> GCC 4.7 (and newer versions of clang) REQUIRE a space between
>>> the format the string and a format specifier (a # defined "string")
>>> in an string concatenation to be C++11 conformant.
>> [snip] 
>>> ++++++++++----------
>>> 35 files changed, 126 insertions(+), 126 deletions(-)
>>> ----------------------------------------------------------------------
>> 
>> Which essentially boils down to:
>> 
>> sed s|%"PRId64"|%" PRId64"|g
>> 
>> Because that's what the C++11 spec says, and that's what GCC 4.7,
>> and clang now, thanks to -std=c++11 enforce. TS-1582 is only the
>> first sign of this breakage, and TS-1853 is what follows.
>> 
>> Zhao is quite unhappy with such a massive change. Understandably
>> because he is still working, in a branch, on SSD optimizations.
>> 
>> This change makes merging "upstream" changes for him much more
>> difficult. Before I revert this commit again, I'd like to
>> bring this to attention, because:
>> 
>>   trunk is CTR, and I'd like to keep it that way.
>> 
>> There's a number of options we have from here, and I'd really
>> like we figure this out now.
> 
> Obviously I did not test this on GCC 4.7 like I should have.

Oh, and when people (like me) commit breaking changes like this we should feel comfortable with just reverting them IMHO ...

> If I had I would have realized that this change has more impact that I was expecting. I'm ok with reverting these changes and rescheduling at a more convenient time. I can commit a change to disable C++11 mode for now.
> 
> 
>> 
>> i
>> 
>> -- 
>> Igor Galić
>> 
>> Tel: +43 (0) 664 886 22 883
>> Mail: i.galic@brainsware.org
>> URL: http://brainsware.org/
>> GPG: 6880 4155 74BD FD7C B515  2EA5 4B1D 9E08 A097 C9AE
>> 
> 


Re: std=c++11 breaks trunk, what now?

Posted by James Peach <jp...@apache.org>.
On 21/11/2012, at 9:27 AM, Igor Galić <i....@brainsware.org> wrote:

> 
> Hey folks,
> 
> regarding this MASSIVE change:
> 
>> TS-1582 space between string and format specifiers
>> 
>> GCC 4.7 (and newer versions of clang) REQUIRE a space between
>> the format the string and a format specifier (a # defined "string")
>> in an string concatenation to be C++11 conformant.
> [snip] 
>> ++++++++++----------
>> 35 files changed, 126 insertions(+), 126 deletions(-)
>> ----------------------------------------------------------------------
> 
> Which essentially boils down to:
> 
> sed s|%"PRId64"|%" PRId64"|g
> 
> Because that's what the C++11 spec says, and that's what GCC 4.7,
> and clang now, thanks to -std=c++11 enforce. TS-1582 is only the
> first sign of this breakage, and TS-1853 is what follows.
> 
> Zhao is quite unhappy with such a massive change. Understandably
> because he is still working, in a branch, on SSD optimizations.
> 
> This change makes merging "upstream" changes for him much more
> difficult. Before I revert this commit again, I'd like to
> bring this to attention, because:
> 
>    trunk is CTR, and I'd like to keep it that way.
> 
> There's a number of options we have from here, and I'd really
> like we figure this out now.

Obviously I did not test this on GCC 4.7 like I should have. If I had I would have realized that this change has more impact that I was expecting. I'm ok with reverting these changes and rescheduling at a more convenient time. I can commit a change to disable C++11 mode for now.


> 
> i
> 
> -- 
> Igor Galić
> 
> Tel: +43 (0) 664 886 22 883
> Mail: i.galic@brainsware.org
> URL: http://brainsware.org/
> GPG: 6880 4155 74BD FD7C B515  2EA5 4B1D 9E08 A097 C9AE
> 


std=c++11 breaks trunk, what now?

Posted by Igor Galić <i....@brainsware.org>.
Hey folks,

regarding this MASSIVE change:

> TS-1582 space between string and format specifiers
> 
> GCC 4.7 (and newer versions of clang) REQUIRE a space between
> the format the string and a format specifier (a # defined "string")
> in an string concatenation to be C++11 conformant.
[snip] 
>  ++++++++++----------
>  35 files changed, 126 insertions(+), 126 deletions(-)
> ----------------------------------------------------------------------

Which essentially boils down to:

 sed s|%"PRId64"|%" PRId64"|g

Because that's what the C++11 spec says, and that's what GCC 4.7,
and clang now, thanks to -std=c++11 enforce. TS-1582 is only the
first sign of this breakage, and TS-1853 is what follows.

Zhao is quite unhappy with such a massive change. Understandably
because he is still working, in a branch, on SSD optimizations.

This change makes merging "upstream" changes for him much more
difficult. Before I revert this commit again, I'd like to
bring this to attention, because:

    trunk is CTR, and I'd like to keep it that way.

There's a number of options we have from here, and I'd really
like we figure this out now.

i

-- 
Igor Galić

Tel: +43 (0) 664 886 22 883
Mail: i.galic@brainsware.org
URL: http://brainsware.org/
GPG: 6880 4155 74BD FD7C B515  2EA5 4B1D 9E08 A097 C9AE