You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@trafficserver.apache.org by je...@ci.trafficserver.apache.org on 2015/07/15 07:48:19 UTC

Build failed in Jenkins: clang-format #21

See <https://ci.trafficserver.apache.org/job/clang-format/21/changes>

Changes:

[briang] HostDB HTTP UI: Add a listall endpoint. This closes #240

------------------------------------------
[...truncated 4439 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index 6abb7b0..6b79b8d 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1047,34 +1047,33 @@ HostDBProcessor::getall(Continuation *cont)
 
   HOSTDB_INCREMENT_DYN_STAT(hostdb_total_lookups_stat);
 
-Action *
-HostDBProcessor::iterate(Continuation *cont)
-{
-  ink_assert(cont->mutex->thread_holding == this_ethread());
-  EThread *thread = cont->mutex->thread_holding;
-  ProxyMutex *mutex = thread->mutex;
+  Action *HostDBProcessor::iterate(Continuation * cont)
+  {
+    ink_assert(cont->mutex->thread_holding == this_ethread());
+    EThread *thread = cont->mutex->thread_holding;
+    ProxyMutex *mutex = thread->mutex;
 
-  HOSTDB_INCREMENT_DYN_STAT(hostdb_total_lookups_stat);
+    HOSTDB_INCREMENT_DYN_STAT(hostdb_total_lookups_stat);
 
 
-  HostDBContinuation *c = hostDBContAllocator.alloc();
-  HostDBContinuation::Options copt;
-  copt.cont = cont;
-  copt.force_dns = false;
-  copt.timeout = 0;
-  copt.host_res_style = HOST_RES_NONE;
-  c->init(HostDBMD5(), copt);
-  c->current_iterate_pos = 0;
-  SET_CONTINUATION_HANDLER(c, (HostDBContHandler)&HostDBContinuation::iterateEvent);
+    HostDBContinuation *c = hostDBContAllocator.alloc();
+    HostDBContinuation::Options copt;
+    copt.cont = cont;
+    copt.force_dns = false;
+    copt.timeout = 0;
+    copt.host_res_style = HOST_RES_NONE;
+    c->init(HostDBMD5(), copt);
+    c->current_iterate_pos = 0;
+    SET_CONTINUATION_HANDLER(c, (HostDBContHandler)&HostDBContinuation::iterateEvent);
 
-  if (thread->mutex == cont->mutex) {
-    thread->schedule_in(c, HOST_DB_RETRY_PERIOD);
-  } else {
-    dnsProcessor.thread->schedule_imm(c);
-  }
+    if (thread->mutex == cont->mutex) {
+      thread->schedule_in(c, HOST_DB_RETRY_PERIOD);
+    } else {
+      dnsProcessor.thread->schedule_imm(c);
+    }
 
-  return &c->action;
-}
+    return &c->action;
+  }
 
   HostDBContinuation *c = hostDBContAllocator.alloc();
   HostDBContinuation::Options copt;
@@ -1865,30 +1864,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -1935,15 +1936,15 @@ HostDBContinuation::probeAllEvent(int event, Event *e)
   }
 
   for (int i = 0; i < hostDB.buckets; ++i) {
-     ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(i);
-     SCOPED_MUTEX_LOCK(lock, bucket_mutex, t);
-     for (unsigned int l = 0; l < hostDB.levels; ++l) {
-       HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * i);
-       if (!r->deleted && !r->failed()) {
-         action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-       }
-     }
-   }
+    ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(i);
+    SCOPED_MUTEX_LOCK(lock, bucket_mutex, t);
+    for (unsigned int l = 0; l < hostDB.levels; ++l) {
+      HostDBInfo *r = reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * i);
+      if (!r->deleted && !r->failed()) {
+        action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+      }
+    }
+  }
 
   action.continuation->handleEvent(EVENT_DONE, NULL);
   hostdb_cont_free(this);
@@ -2474,7 +2475,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2489,7 +2490,7 @@ struct ShowHostDB : public ShowCont {
     HostDBInfo *r = (HostDBInfo *)e;
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
@@ -2499,7 +2500,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2514,7 +2515,7 @@ struct ShowHostDB : public ShowCont {
     HostDBInfo *r = (HostDBInfo *)e;
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index 37719f6..900e047 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 2b491c4..e84e7d1 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -537,7 +537,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure

Jenkins build is back to normal : clang-format #27

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/27/changes>


Build failed in Jenkins: clang-format #26

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/26/changes>

Changes:

[solidwallofcode] TS-3754: Fix potential bad _buf_end in IOBuffer::set

------------------------------------------
[...truncated 4339 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICPProcessor.h
src/proxy/ICPProcessor.h
+ clang-format -i src/proxy/ICPProcessor.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkAPITest.cc
src/proxy/InkAPITest.cc
+ clang-format -i src/proxy/InkAPITest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/EventName.cc
src/proxy/EventName.cc
+ clang-format -i src/proxy/EventName.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CompletionUtil.h
src/proxy/CompletionUtil.h
+ clang-format -i src/proxy/CompletionUtil.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ReverseProxy.h
src/proxy/ReverseProxy.h
+ clang-format -i src/proxy/ReverseProxy.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/Prefetch.cc
src/proxy/Prefetch.cc
+ clang-format -i src/proxy/Prefetch.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/TestPreProc.h
src/proxy/TestPreProc.h
+ clang-format -i src/proxy/TestPreProc.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkPool_r.h
src/proxy/InkPool_r.h
+ clang-format -i src/proxy/InkPool_r.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/DynamicStats.h
src/proxy/DynamicStats.h
+ clang-format -i src/proxy/DynamicStats.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatSystem.cc
src/proxy/StatSystem.cc
+ clang-format -i src/proxy/StatSystem.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatPages.h
src/proxy/StatPages.h
+ clang-format -i src/proxy/StatPages.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CacheControl.cc
src/proxy/CacheControl.cc
+ clang-format -i src/proxy/CacheControl.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICP.cc
src/proxy/ICP.cc
+ clang-format -i src/proxy/ICP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ControlBase.h
src/proxy/ControlBase.h
+ clang-format -i src/proxy/ControlBase.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.cc
src/proxy/hdrs/URL.cc
+ clang-format -i src/proxy/hdrs/URL.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.h
src/proxy/hdrs/MIME.h
+ clang-format -i src/proxy/hdrs/MIME.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.h
src/proxy/hdrs/HdrTest.h
+ clang-format -i src/proxy/hdrs/HdrTest.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.cc
src/proxy/hdrs/HdrTest.cc
+ clang-format -i src/proxy/hdrs/HdrTest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.cc
src/proxy/hdrs/HTTP.cc
+ clang-format -i src/proxy/hdrs/HTTP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.cc
src/proxy/hdrs/HttpCompat.cc
+ clang-format -i src/proxy/hdrs/HttpCompat.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.h
src/proxy/hdrs/HdrUtils.h
+ clang-format -i src/proxy/hdrs/HdrUtils.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.cc
src/proxy/hdrs/HdrUtils.cc
+ clang-format -i src/proxy/hdrs/HdrUtils.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.cc
src/proxy/hdrs/HdrToken.cc
+ clang-format -i src/proxy/hdrs/HdrToken.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTSOnly.cc
src/proxy/hdrs/HdrTSOnly.cc
+ clang-format -i src/proxy/hdrs/HdrTSOnly.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.cc
src/proxy/hdrs/HdrHeap.cc
+ clang-format -i src/proxy/hdrs/HdrHeap.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index df302d7..f0319aa 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1838,30 +1838,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -2413,7 +2415,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2427,7 +2429,7 @@ struct ShowHostDB : public ShowCont {
   {
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index f5acf1f..ffebfe4 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 54c938a..5cfa025 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -538,7 +538,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: clang-format #25

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/25/changes>

Changes:

[solidwallofcode] TS-3769: Fix coverity complaint about NULL reference.

------------------------------------------
[...truncated 4339 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICPProcessor.h
src/proxy/ICPProcessor.h
+ clang-format -i src/proxy/ICPProcessor.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkAPITest.cc
src/proxy/InkAPITest.cc
+ clang-format -i src/proxy/InkAPITest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/EventName.cc
src/proxy/EventName.cc
+ clang-format -i src/proxy/EventName.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CompletionUtil.h
src/proxy/CompletionUtil.h
+ clang-format -i src/proxy/CompletionUtil.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ReverseProxy.h
src/proxy/ReverseProxy.h
+ clang-format -i src/proxy/ReverseProxy.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/Prefetch.cc
src/proxy/Prefetch.cc
+ clang-format -i src/proxy/Prefetch.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/TestPreProc.h
src/proxy/TestPreProc.h
+ clang-format -i src/proxy/TestPreProc.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkPool_r.h
src/proxy/InkPool_r.h
+ clang-format -i src/proxy/InkPool_r.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/DynamicStats.h
src/proxy/DynamicStats.h
+ clang-format -i src/proxy/DynamicStats.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatSystem.cc
src/proxy/StatSystem.cc
+ clang-format -i src/proxy/StatSystem.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatPages.h
src/proxy/StatPages.h
+ clang-format -i src/proxy/StatPages.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CacheControl.cc
src/proxy/CacheControl.cc
+ clang-format -i src/proxy/CacheControl.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICP.cc
src/proxy/ICP.cc
+ clang-format -i src/proxy/ICP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ControlBase.h
src/proxy/ControlBase.h
+ clang-format -i src/proxy/ControlBase.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.cc
src/proxy/hdrs/URL.cc
+ clang-format -i src/proxy/hdrs/URL.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.h
src/proxy/hdrs/MIME.h
+ clang-format -i src/proxy/hdrs/MIME.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.h
src/proxy/hdrs/HdrTest.h
+ clang-format -i src/proxy/hdrs/HdrTest.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.cc
src/proxy/hdrs/HdrTest.cc
+ clang-format -i src/proxy/hdrs/HdrTest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.cc
src/proxy/hdrs/HTTP.cc
+ clang-format -i src/proxy/hdrs/HTTP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.cc
src/proxy/hdrs/HttpCompat.cc
+ clang-format -i src/proxy/hdrs/HttpCompat.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.h
src/proxy/hdrs/HdrUtils.h
+ clang-format -i src/proxy/hdrs/HdrUtils.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.cc
src/proxy/hdrs/HdrUtils.cc
+ clang-format -i src/proxy/hdrs/HdrUtils.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.cc
src/proxy/hdrs/HdrToken.cc
+ clang-format -i src/proxy/hdrs/HdrToken.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTSOnly.cc
src/proxy/hdrs/HdrTSOnly.cc
+ clang-format -i src/proxy/hdrs/HdrTSOnly.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.cc
src/proxy/hdrs/HdrHeap.cc
+ clang-format -i src/proxy/hdrs/HdrHeap.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index df302d7..f0319aa 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1838,30 +1838,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -2413,7 +2415,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2427,7 +2429,7 @@ struct ShowHostDB : public ShowCont {
   {
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index f5acf1f..ffebfe4 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 54c938a..5cfa025 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -538,7 +538,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: clang-format #24

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/24/>

------------------------------------------
[...truncated 4336 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICPProcessor.h
src/proxy/ICPProcessor.h
+ clang-format -i src/proxy/ICPProcessor.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkAPITest.cc
src/proxy/InkAPITest.cc
+ clang-format -i src/proxy/InkAPITest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/EventName.cc
src/proxy/EventName.cc
+ clang-format -i src/proxy/EventName.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CompletionUtil.h
src/proxy/CompletionUtil.h
+ clang-format -i src/proxy/CompletionUtil.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ReverseProxy.h
src/proxy/ReverseProxy.h
+ clang-format -i src/proxy/ReverseProxy.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/Prefetch.cc
src/proxy/Prefetch.cc
+ clang-format -i src/proxy/Prefetch.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/TestPreProc.h
src/proxy/TestPreProc.h
+ clang-format -i src/proxy/TestPreProc.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkPool_r.h
src/proxy/InkPool_r.h
+ clang-format -i src/proxy/InkPool_r.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/DynamicStats.h
src/proxy/DynamicStats.h
+ clang-format -i src/proxy/DynamicStats.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatSystem.cc
src/proxy/StatSystem.cc
+ clang-format -i src/proxy/StatSystem.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatPages.h
src/proxy/StatPages.h
+ clang-format -i src/proxy/StatPages.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CacheControl.cc
src/proxy/CacheControl.cc
+ clang-format -i src/proxy/CacheControl.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICP.cc
src/proxy/ICP.cc
+ clang-format -i src/proxy/ICP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ControlBase.h
src/proxy/ControlBase.h
+ clang-format -i src/proxy/ControlBase.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.cc
src/proxy/hdrs/URL.cc
+ clang-format -i src/proxy/hdrs/URL.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.h
src/proxy/hdrs/MIME.h
+ clang-format -i src/proxy/hdrs/MIME.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.h
src/proxy/hdrs/HdrTest.h
+ clang-format -i src/proxy/hdrs/HdrTest.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.cc
src/proxy/hdrs/HdrTest.cc
+ clang-format -i src/proxy/hdrs/HdrTest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.cc
src/proxy/hdrs/HTTP.cc
+ clang-format -i src/proxy/hdrs/HTTP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.cc
src/proxy/hdrs/HttpCompat.cc
+ clang-format -i src/proxy/hdrs/HttpCompat.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.h
src/proxy/hdrs/HdrUtils.h
+ clang-format -i src/proxy/hdrs/HdrUtils.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.cc
src/proxy/hdrs/HdrUtils.cc
+ clang-format -i src/proxy/hdrs/HdrUtils.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.cc
src/proxy/hdrs/HdrToken.cc
+ clang-format -i src/proxy/hdrs/HdrToken.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTSOnly.cc
src/proxy/hdrs/HdrTSOnly.cc
+ clang-format -i src/proxy/hdrs/HdrTSOnly.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.cc
src/proxy/hdrs/HdrHeap.cc
+ clang-format -i src/proxy/hdrs/HdrHeap.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index df302d7..f0319aa 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1838,30 +1838,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -2413,7 +2415,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2427,7 +2429,7 @@ struct ShowHostDB : public ShowCont {
   {
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index f5acf1f..ffebfe4 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 54c938a..5cfa025 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -538,7 +538,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: clang-format #23

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/23/changes>

Changes:

[briang] HostDB HTTP UI: Fix merge issue. This closes #240

------------------------------------------
[...truncated 4336 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICPProcessor.h
src/proxy/ICPProcessor.h
+ clang-format -i src/proxy/ICPProcessor.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkAPITest.cc
src/proxy/InkAPITest.cc
+ clang-format -i src/proxy/InkAPITest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/EventName.cc
src/proxy/EventName.cc
+ clang-format -i src/proxy/EventName.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CompletionUtil.h
src/proxy/CompletionUtil.h
+ clang-format -i src/proxy/CompletionUtil.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ReverseProxy.h
src/proxy/ReverseProxy.h
+ clang-format -i src/proxy/ReverseProxy.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/Prefetch.cc
src/proxy/Prefetch.cc
+ clang-format -i src/proxy/Prefetch.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/TestPreProc.h
src/proxy/TestPreProc.h
+ clang-format -i src/proxy/TestPreProc.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkPool_r.h
src/proxy/InkPool_r.h
+ clang-format -i src/proxy/InkPool_r.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/DynamicStats.h
src/proxy/DynamicStats.h
+ clang-format -i src/proxy/DynamicStats.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatSystem.cc
src/proxy/StatSystem.cc
+ clang-format -i src/proxy/StatSystem.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatPages.h
src/proxy/StatPages.h
+ clang-format -i src/proxy/StatPages.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CacheControl.cc
src/proxy/CacheControl.cc
+ clang-format -i src/proxy/CacheControl.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICP.cc
src/proxy/ICP.cc
+ clang-format -i src/proxy/ICP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ControlBase.h
src/proxy/ControlBase.h
+ clang-format -i src/proxy/ControlBase.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.cc
src/proxy/hdrs/URL.cc
+ clang-format -i src/proxy/hdrs/URL.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.h
src/proxy/hdrs/MIME.h
+ clang-format -i src/proxy/hdrs/MIME.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.h
src/proxy/hdrs/HdrTest.h
+ clang-format -i src/proxy/hdrs/HdrTest.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.cc
src/proxy/hdrs/HdrTest.cc
+ clang-format -i src/proxy/hdrs/HdrTest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.cc
src/proxy/hdrs/HTTP.cc
+ clang-format -i src/proxy/hdrs/HTTP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.cc
src/proxy/hdrs/HttpCompat.cc
+ clang-format -i src/proxy/hdrs/HttpCompat.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.h
src/proxy/hdrs/HdrUtils.h
+ clang-format -i src/proxy/hdrs/HdrUtils.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.cc
src/proxy/hdrs/HdrUtils.cc
+ clang-format -i src/proxy/hdrs/HdrUtils.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.cc
src/proxy/hdrs/HdrToken.cc
+ clang-format -i src/proxy/hdrs/HdrToken.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTSOnly.cc
src/proxy/hdrs/HdrTSOnly.cc
+ clang-format -i src/proxy/hdrs/HdrTSOnly.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.cc
src/proxy/hdrs/HdrHeap.cc
+ clang-format -i src/proxy/hdrs/HdrHeap.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index df302d7..f0319aa 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1838,30 +1838,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -2413,7 +2415,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2427,7 +2429,7 @@ struct ShowHostDB : public ShowCont {
   {
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index f5acf1f..ffebfe4 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 54c938a..5cfa025 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -538,7 +538,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: clang-format #22

Posted by je...@ci.trafficserver.apache.org.
See <https://ci.trafficserver.apache.org/job/clang-format/22/changes>

Changes:

[briang] HostDB HTTP UI: Fix merge issue. This closes #240

------------------------------------------
[...truncated 4339 lines...]
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICPProcessor.h
src/proxy/ICPProcessor.h
+ clang-format -i src/proxy/ICPProcessor.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkAPITest.cc
src/proxy/InkAPITest.cc
+ clang-format -i src/proxy/InkAPITest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/EventName.cc
src/proxy/EventName.cc
+ clang-format -i src/proxy/EventName.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CompletionUtil.h
src/proxy/CompletionUtil.h
+ clang-format -i src/proxy/CompletionUtil.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ReverseProxy.h
src/proxy/ReverseProxy.h
+ clang-format -i src/proxy/ReverseProxy.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/Prefetch.cc
src/proxy/Prefetch.cc
+ clang-format -i src/proxy/Prefetch.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/TestPreProc.h
src/proxy/TestPreProc.h
+ clang-format -i src/proxy/TestPreProc.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/InkPool_r.h
src/proxy/InkPool_r.h
+ clang-format -i src/proxy/InkPool_r.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/DynamicStats.h
src/proxy/DynamicStats.h
+ clang-format -i src/proxy/DynamicStats.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatSystem.cc
src/proxy/StatSystem.cc
+ clang-format -i src/proxy/StatSystem.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/StatPages.h
src/proxy/StatPages.h
+ clang-format -i src/proxy/StatPages.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/CacheControl.cc
src/proxy/CacheControl.cc
+ clang-format -i src/proxy/CacheControl.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ICP.cc
src/proxy/ICP.cc
+ clang-format -i src/proxy/ICP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/ControlBase.h
src/proxy/ControlBase.h
+ clang-format -i src/proxy/ControlBase.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.cc
src/proxy/hdrs/URL.cc
+ clang-format -i src/proxy/hdrs/URL.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.h
src/proxy/hdrs/MIME.h
+ clang-format -i src/proxy/hdrs/MIME.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.h
src/proxy/hdrs/HdrTest.h
+ clang-format -i src/proxy/hdrs/HdrTest.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTest.cc
src/proxy/hdrs/HdrTest.cc
+ clang-format -i src/proxy/hdrs/HdrTest.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.cc
src/proxy/hdrs/HTTP.cc
+ clang-format -i src/proxy/hdrs/HTTP.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.cc
src/proxy/hdrs/HttpCompat.cc
+ clang-format -i src/proxy/hdrs/HttpCompat.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.h
src/proxy/hdrs/HdrUtils.h
+ clang-format -i src/proxy/hdrs/HdrUtils.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrUtils.cc
src/proxy/hdrs/HdrUtils.cc
+ clang-format -i src/proxy/hdrs/HdrUtils.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.cc
src/proxy/hdrs/HdrToken.cc
+ clang-format -i src/proxy/hdrs/HdrToken.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrTSOnly.cc
src/proxy/hdrs/HdrTSOnly.cc
+ clang-format -i src/proxy/hdrs/HdrTSOnly.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.cc
src/proxy/hdrs/HdrHeap.cc
+ clang-format -i src/proxy/hdrs/HdrHeap.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_urlhash.cc
src/proxy/hdrs/test_urlhash.cc
+ clang-format -i src/proxy/hdrs/test_urlhash.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HTTP.h
src/proxy/hdrs/HTTP.h
+ clang-format -i src/proxy/hdrs/HTTP.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/load_http_hdr.cc
src/proxy/hdrs/load_http_hdr.cc
+ clang-format -i src/proxy/hdrs/load_http_hdr.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/URL.h
src/proxy/hdrs/URL.h
+ clang-format -i src/proxy/hdrs/URL.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/MIME.cc
src/proxy/hdrs/MIME.cc
+ clang-format -i src/proxy/hdrs/MIME.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrHeap.h
src/proxy/hdrs/HdrHeap.h
+ clang-format -i src/proxy/hdrs/HdrHeap.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HdrToken.h
src/proxy/hdrs/HdrToken.h
+ clang-format -i src/proxy/hdrs/HdrToken.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/test_header.cc
src/proxy/hdrs/test_header.cc
+ clang-format -i src/proxy/hdrs/test_header.cc
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/hdrs/HttpCompat.h
src/proxy/hdrs/HttpCompat.h
+ clang-format -i src/proxy/hdrs/HttpCompat.h
+ for f in '`find src -iname \*.[ch] -o -iname \*.cc | fgrep -v -e lib/luajit -e lib/tsconfig`'
+ echo src/proxy/sac.cc
src/proxy/sac.cc
+ clang-format -i src/proxy/sac.cc
+ cd src
+ git diff --exit-code
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index 0919b00..99faa21 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -1838,30 +1838,32 @@ HostDBContinuation::iterateEvent(int event, Event *e)
 
   // let's iterate through another record and then reschedule ourself.
   if (current_iterate_pos < hostDB.buckets) {
-     // do 100 at a time
-     int end = min(current_iterate_pos + 100, hostDB.buckets);
-     for (; current_iterate_pos < end; ++current_iterate_pos) {
-       ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
-       MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
-       if (!lock_bucket.is_locked()) {
-         // we couldn't get the bucket lock, let's just reschedule and try later.
-         Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
-         mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
-         return EVENT_CONT;
-       }
-
-       for (unsigned int l = 0; l < hostDB.levels; ++l) {
-         HostDBInfo *r = reinterpret_cast<HostDBInfo*>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
-         if (!r->deleted && !r->failed()) {
-           action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void*>(r));
-         }
-       }
-     }
-
-     // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
-     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos, hostDB.buckets);
-     mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
-     return EVENT_CONT;
+    // do 100 at a time
+    int end = min(current_iterate_pos + 100, hostDB.buckets);
+    for (; current_iterate_pos < end; ++current_iterate_pos) {
+      ProxyMutex *bucket_mutex = hostDB.lock_for_bucket(current_iterate_pos);
+      MUTEX_TRY_LOCK_FOR(lock_bucket, bucket_mutex, t, this);
+      if (!lock_bucket.is_locked()) {
+        // we couldn't get the bucket lock, let's just reschedule and try later.
+        Debug("hostdb", "iterateEvent event=%d eventp=%p: reschedule due to not getting bucket mutex", event, e);
+        mutex->thread_holding->schedule_in(this, HOST_DB_RETRY_PERIOD);
+        return EVENT_CONT;
+      }
+
+      for (unsigned int l = 0; l < hostDB.levels; ++l) {
+        HostDBInfo *r =
+          reinterpret_cast<HostDBInfo *>(hostDB.data + hostDB.level_offset[l] + hostDB.bucketsize[l] * current_iterate_pos);
+        if (!r->deleted && !r->failed()) {
+          action.continuation->handleEvent(EVENT_INTERVAL, static_cast<void *>(r));
+        }
+      }
+    }
+
+    // And reschedule ourselves to pickup the next bucket after HOST_DB_RETRY_PERIOD.
+    Debug("hostdb", "iterateEvent event=%d eventp=%p: completed current iteration %d of %d", event, e, current_iterate_pos,
+          hostDB.buckets);
+    mutex->thread_holding->schedule_in(this, HOST_DB_ITERATE_PERIOD);
+    return EVENT_CONT;
   } else {
     Debug("hostdb", "iterateEvent event=%d eventp=%p: completed FINAL iteration %d", event, e, current_iterate_pos);
     // if there are no more buckets, then we're done.
@@ -2413,7 +2415,7 @@ struct ShowHostDB : public ShowCont {
   }
 
   int
-  showAll(int event , Event *e)
+  showAll(int event, Event *e)
   {
     CHECK_SHOW(begin("HostDB All Records"));
     CHECK_SHOW(show("<hr>"));
@@ -2428,7 +2430,7 @@ struct ShowHostDB : public ShowCont {
     HostDBInfo *r = (HostDBInfo *)e;
     if (event == EVENT_INTERVAL) {
       HostDBInfo *r = reinterpret_cast<HostDBInfo *>(e);
-      return showOne(r,false,event,e);
+      return showOne(r, false, event, e);
     } else if (event == EVENT_DONE) {
       return complete(event, e);
     } else {
diff --git a/iocore/hostdb/I_HostDBProcessor.h b/iocore/hostdb/I_HostDBProcessor.h
index f5acf1f..ffebfe4 100644
--- a/iocore/hostdb/I_HostDBProcessor.h
+++ b/iocore/hostdb/I_HostDBProcessor.h
@@ -418,7 +418,7 @@ struct HostDBCache;
 typedef void (Continuation::*process_hostdb_info_pfn)(HostDBInfo *r);
 typedef void (Continuation::*process_srv_info_pfn)(HostDBInfo *r);
 
-  Action *iterate(Continuation *cont);
+Action *iterate(Continuation *cont);
 
 /** The Host Databse access interface. */
 struct HostDBProcessor : public Processor {
diff --git a/iocore/hostdb/P_HostDBProcessor.h b/iocore/hostdb/P_HostDBProcessor.h
index 54c938a..5cfa025 100644
--- a/iocore/hostdb/P_HostDBProcessor.h
+++ b/iocore/hostdb/P_HostDBProcessor.h
@@ -538,7 +538,8 @@ struct HostDBContinuation : public Continuation {
 
   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)
+      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);
Build step 'Execute shell' marked build as failure