You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mesos.apache.org by be...@apache.org on 2014/05/03 04:36:18 UTC

[1/7] git commit: Updated indentation in Mesos configure.ac.

Repository: mesos
Updated Branches:
  refs/heads/master 1a088bf48 -> f88d5dc1f


Updated indentation in Mesos configure.ac.


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

Branch: refs/heads/master
Commit: 0b87e3c093eebc8ce3fbfd168a31ea86e5163584
Parents: 2c4b2be
Author: Benjamin Hindman <be...@gmail.com>
Authored: Fri May 2 18:38:08 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 18:40:36 2014 -0700

----------------------------------------------------------------------
 configure.ac | 66 +++++++++++++++++++++++++++----------------------------
 1 file changed, 33 insertions(+), 33 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/0b87e3c0/configure.ac
----------------------------------------------------------------------
diff --git a/configure.ac b/configure.ac
index 27b2ac8..69acaa1 100644
--- a/configure.ac
+++ b/configure.ac
@@ -221,33 +221,33 @@ fi
 # CPPFLAGS while extending it by /include and to LDFLAGS while
 # extending it by /lib.
 if test -n "`echo $with_leveldb`"; then
-    CPPFLAGS="$CPPFLAGS -I${with_leveldb}/include"
-    LDFLAGS="$LDFLAGS -L${with_leveldb}/lib"
+  CPPFLAGS="$CPPFLAGS -I${with_leveldb}/include"
+  LDFLAGS="$LDFLAGS -L${with_leveldb}/lib"
 fi
 
 # Check if ZooKeeper prefix path was supplied and if so, add it to
 # CPPFLAGS while extending it by /include and to LDFLAGS while
 # extending it by /lib.
 if test -n "`echo $with_zookeeper`"; then
-    CPPFLAGS="$CPPFLAGS -I${with_zookeeper}/include"
-    LDFLAGS="$LDFLAGS -L${with_zookeeper}/lib"
+  CPPFLAGS="$CPPFLAGS -I${with_zookeeper}/include"
+  LDFLAGS="$LDFLAGS -L${with_zookeeper}/lib"
 elif test "x$enable_bundled" = "xno"; then
-    CPPFLAGS="$CPPFLAGS -I/usr/include/zookeeper"
+  CPPFLAGS="$CPPFLAGS -I/usr/include/zookeeper"
 fi
 
 # Check if user has asked us to use a preinstalled LevelDB, or if they asked
 # us to ignore all bundled libraries while compiling and linking.
 if test "x$without_bundled_leveldb" = "xyes" || \
    test "x$enable_bundled" != "xyes"; then
-	# Check if headers and library were located.
-	AC_CHECK_HEADERS([leveldb/db.h],
-			[AC_CHECK_LIB([leveldb],
-				      [leveldb_open],
-				      [found_leveldb=yes])])
-	if test "x$found_leveldb" = "xyes"; then
-		with_bundled_leveldb=no
-	else
-		AC_MSG_ERROR([cannot find LevelDB
+  # Check if headers and library were located.
+  AC_CHECK_HEADERS([leveldb/db.h],
+                   [AC_CHECK_LIB([leveldb],
+                                 [leveldb_open],
+                                 [found_leveldb=yes])])
+  if test "x$found_leveldb" = "xyes"; then
+    with_bundled_leveldb=no
+  else
+    AC_MSG_ERROR([cannot find LevelDB
 -------------------------------------------------------------------
 You have requested the use of a non-bundled LevelDB but no suitable
 LevelDB could be found.
@@ -257,9 +257,9 @@ path via --with-leveldb=DIR, or check that the path you provided is
 correct if you're already doing this.
 -------------------------------------------------------------------
 ])
-	fi
+  fi
 else
-    with_bundled_leveldb=yes
+  with_bundled_leveldb=yes
 fi
 
 AM_CONDITIONAL([WITH_BUNDLED_LEVELDB],
@@ -269,15 +269,15 @@ AM_CONDITIONAL([WITH_BUNDLED_LEVELDB],
 # us to ignore all bundled libraries while compiling and linking.
 if test "x$without_bundled_zookeeper" = "xyes" || \
    test "x$enable_bundled" != "xyes"; then
-	# Check if headers and library were located.
-	AC_CHECK_HEADERS([zookeeper.h],
-			[AC_CHECK_LIB([zookeeper_mt],
-				      [zookeeper_init],
-				      [found_zookeeper=yes])])
-	if test "x$found_zookeeper" = "xyes"; then
-		with_bundled_zookeeper=no
-	else
-		AC_MSG_ERROR([cannot find ZooKeeper
+  # Check if headers and library were located.
+  AC_CHECK_HEADERS([zookeeper.h],
+                   [AC_CHECK_LIB([zookeeper_mt],
+				 [zookeeper_init],
+				 [found_zookeeper=yes])])
+  if test "x$found_zookeeper" = "xyes"; then
+    with_bundled_zookeeper=no
+  else
+    AC_MSG_ERROR([cannot find ZooKeeper
 -------------------------------------------------------------------
 You have requested the use of a non-bundled ZooKeeper but no suitable
 ZooKeeper could be found.
@@ -287,13 +287,13 @@ path via --with-zookeeper=DIR, or check that the path you provided is
 correct if you're already doing this
 -------------------------------------------------------------------
 ])
-	fi
+  fi
 else
-    with_bundled_zookeeper=yes
+  with_bundled_zookeeper=yes
 fi
 
 AM_CONDITIONAL([WITH_BUNDLED_ZOOKEEPER],
-	   [test "x$with_bundled_zookeeper" = "xyes"])
+               [test "x$with_bundled_zookeeper" = "xyes"])
 
 # Check if we're using clang.
 AC_MSG_CHECKING([if compiling with clang])
@@ -577,11 +577,11 @@ if test "x$enable_python" = "xyes"; then
   # PYTHON is not set (necessary to run our examples).
   AM_PATH_PYTHON([2.6],,
                  [AC_MSG_ERROR([mesos requires Python >= 2.6
-  -------------------------------------------------------------------
-  If you already have Python 2.6 installed (and it's on the path),
-  you might want to check if you have the PYTHON environment variable
-  set to an older version of Python.
-  -------------------------------------------------------------------
+-------------------------------------------------------------------
+If you already have Python 2.6 installed (and it's on the path),
+you might want to check if you have the PYTHON environment variable
+set to an older version of Python.
+-------------------------------------------------------------------
   ])])
 
   # Next we ensure we have the Python development libraries.


[2/7] git commit: Updated indentation in libprocess configure.ac.

Posted by be...@apache.org.
Updated indentation in libprocess configure.ac.


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

Branch: refs/heads/master
Commit: 2c4b2be892b0523e43260f54123fb7d8499321d7
Parents: 1a088bf
Author: Benjamin Hindman <be...@gmail.com>
Authored: Fri May 2 18:37:45 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 18:40:36 2014 -0700

----------------------------------------------------------------------
 3rdparty/libprocess/configure.ac | 30 +++++++++++++++---------------
 1 file changed, 15 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/2c4b2be8/3rdparty/libprocess/configure.ac
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/configure.ac b/3rdparty/libprocess/configure.ac
index fc5e2ad..0c7cc6d 100644
--- a/3rdparty/libprocess/configure.ac
+++ b/3rdparty/libprocess/configure.ac
@@ -105,7 +105,7 @@ esac
 # Include directories used by package managers (e.g., MacPorts).
 if test "x$enable_bundled" = "xno" && \
    test "x$OS_NAME" = "xdarwin"; then
-    CPPFLAGS="$CPPFLAGS -I/opt/local/include"
+  CPPFLAGS="$CPPFLAGS -I/opt/local/include"
 fi
 
 # Used for conditionally building source files (e.g., only want to
@@ -113,20 +113,20 @@ fi
 AM_CONDITIONAL([OS_LINUX], [test "x$OS_NAME" = "xlinux"])
 
 if test -n "`echo $with_boost`"; then
-    CPPFLAGS="$CPPFLAGS -I${with_boost}/include"
+  CPPFLAGS="$CPPFLAGS -I${with_boost}/include"
 fi
 
 # Check if user has asked us to use a preinstalled Boost, or if they asked
 # us to ignore all bundled libraries while compiling and linking.
 if test "x$without_bundled_boost" = "xyes" || \
    test "x$enable_bundled" != "xyes"; then
-	# Check if headers and library were located.
-	AC_CHECK_HEADERS([boost/version.hpp], [found_boost=yes])
+  # Check if headers and library were located.
+  AC_CHECK_HEADERS([boost/version.hpp], [found_boost=yes])
 
-	if test "x$found_boost" = "xyes"; then
-		with_bundled_boost=no
-	else
-		AC_MSG_ERROR([cannot find Boost
+  if test "x$found_boost" = "xyes"; then
+    with_bundled_boost=no
+  else
+    AC_MSG_ERROR([cannot find Boost
 -------------------------------------------------------------------
 You have requested the use of a non-bundled Boost but no suitable
 Boost could be found.
@@ -136,9 +136,9 @@ path via --with-boost=DIR, or check that the path you provided is
 correct if you're already doing this.
 -------------------------------------------------------------------
 ])
-	fi
+  fi
 else
-    with_bundled_boost=yes
+  with_bundled_boost=yes
 fi
 
 AM_CONDITIONAL([WITH_BUNDLED_BOOST], [test "x$with_bundled_boost" = "xyes"])
@@ -225,11 +225,11 @@ AM_CONDITIONAL([HAS_GPERFTOOLS], [test "x$gperftools" = "xyes"])
 if test "x$with_zlib" = "xyes"; then
   AC_CHECK_LIB([z], [deflate, gzread, gzwrite, inflate], [],
                [AC_MSG_ERROR([cannot find libz
-  -------------------------------------------------------------------
-  This means HTTP responses will be slower because we cannot use
-  compression; you probably want to download and install zlib, but
-  you can get away without it by doing --without-zlib.
-  -------------------------------------------------------------------
+-------------------------------------------------------------------
+This means HTTP responses will be slower because we cannot use
+compression; you probably want to download and install zlib, but
+you can get away without it by doing --without-zlib.
+-------------------------------------------------------------------
   ])])
 fi
 


[7/7] git commit: Updated Mesos to satisfy whitespace/line_length.

Posted by be...@apache.org.
Updated Mesos to satisfy whitespace/line_length.

Also enabled the whitespace/line_length cpplint rule.

Review: https://reviews.apache.org/r/20994


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

Branch: refs/heads/master
Commit: f88d5dc1f3e160d13f6b8f87a78efd790df22918
Parents: 33b1a6a
Author: Adam B <ad...@mesosphere.io>
Authored: Fri May 2 19:29:58 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 19:33:05 2014 -0700

----------------------------------------------------------------------
 include/mesos/resources.hpp                     |  3 ++-
 include/mesos/values.hpp                        | 12 ++++++----
 src/common/resources.cpp                        |  3 ++-
 src/jvm/java/net.hpp                            |  3 ++-
 src/jvm/org/apache/zookeeper.hpp                |  4 ++--
 src/linux/cgroups.cpp                           | 21 ++++++++++------
 src/log/coordinator.cpp                         |  3 ++-
 src/logging/logging.cpp                         |  4 ++--
 src/master/detector.cpp                         |  3 ++-
 src/master/flags.hpp                            |  2 +-
 src/master/hierarchical_allocator_process.hpp   |  7 +++---
 src/master/master.cpp                           |  8 +++----
 .../native/mesos_scheduler_driver_impl.cpp      | 13 ++++++----
 .../native/mesos_scheduler_driver_impl.hpp      | 25 ++++++++++++--------
 .../containerizer/external_containerizer.hpp    |  3 ++-
 src/slave/containerizer/mesos_containerizer.cpp |  3 ++-
 src/slave/containerizer/mesos_containerizer.hpp |  3 ++-
 src/slave/slave.cpp                             |  7 ++++--
 src/state/zookeeper.cpp                         |  3 ++-
 src/tests/allocator_tests.cpp                   |  4 ++--
 src/tests/cgroups_tests.cpp                     |  5 +++-
 src/tests/containerizer_tests.cpp               |  9 ++++---
 src/tests/gc_tests.cpp                          |  3 ++-
 src/tests/master_tests.cpp                      |  6 +++--
 src/tests/mesos.hpp                             |  3 ++-
 src/tests/resource_offers_tests.cpp             |  6 +++--
 src/tests/resources_tests.cpp                   | 21 ++++++++++------
 src/tests/script.cpp                            |  3 ++-
 src/tests/slave_recovery_tests.cpp              |  9 ++++---
 src/tests/status_update_manager_tests.cpp       |  8 +++----
 src/zookeeper/detector.cpp                      |  3 ++-
 src/zookeeper/group.cpp                         |  4 +++-
 support/mesos-style.py                          |  1 +
 33 files changed, 136 insertions(+), 79 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/include/mesos/resources.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/resources.hpp b/include/mesos/resources.hpp
index 70d8731..8fc347e 100644
--- a/include/mesos/resources.hpp
+++ b/include/mesos/resources.hpp
@@ -304,7 +304,8 @@ public:
   Option<double> cpus() const;
   Option<Bytes> mem() const;
   Option<Bytes> disk() const;
-  Option<Value::Ranges> ports() const; // TODO(vinod): Provide a Ranges abstraction.
+  // TODO(vinod): Provide a Ranges abstraction.
+  Option<Value::Ranges> ports() const;
 
   typedef google::protobuf::RepeatedPtrField<Resource>::iterator
   iterator;

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/include/mesos/values.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/values.hpp b/include/mesos/values.hpp
index 64c138c..1bbf2ca 100644
--- a/include/mesos/values.hpp
+++ b/include/mesos/values.hpp
@@ -28,16 +28,20 @@ namespace mesos {
 std::ostream& operator << (std::ostream& stream, const Value::Scalar& scalar);
 bool operator == (const Value::Scalar& left, const Value::Scalar& right);
 bool operator <= (const Value::Scalar& left, const Value::Scalar& right);
-Value::Scalar operator + (const Value::Scalar& left, const Value::Scalar& right);
-Value::Scalar operator - (const Value::Scalar& left, const Value::Scalar& right);
+Value::Scalar operator + (const Value::Scalar& left,
+                          const Value::Scalar& right);
+Value::Scalar operator - (const Value::Scalar& left,
+                          const Value::Scalar& right);
 Value::Scalar& operator += (Value::Scalar& left, const Value::Scalar& right);
 Value::Scalar& operator -= (Value::Scalar& left, const Value::Scalar& right);
 
 std::ostream& operator << (std::ostream& stream, const Value::Ranges& ranges);
 bool operator == (const Value::Ranges& left, const Value::Ranges& right);
 bool operator <= (const Value::Ranges& left, const Value::Ranges& right);
-Value::Ranges operator + (const Value::Ranges& left, const Value::Ranges& right);
-Value::Ranges operator - (const Value::Ranges& left, const Value::Ranges& right);
+Value::Ranges operator + (const Value::Ranges& left,
+                          const Value::Ranges& right);
+Value::Ranges operator - (const Value::Ranges& left,
+                          const Value::Ranges& right);
 Value::Ranges& operator += (Value::Ranges& left, const Value::Ranges& right);
 Value::Ranges& operator -= (Value::Ranges& left, const Value::Ranges& right);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/common/resources.cpp
----------------------------------------------------------------------
diff --git a/src/common/resources.cpp b/src/common/resources.cpp
index 61c5bda..512dabf 100644
--- a/src/common/resources.cpp
+++ b/src/common/resources.cpp
@@ -243,7 +243,8 @@ Option<Resources> Resources::find(
             Resource potential_ = potential;
             potential_.set_role(remaining.role());
             if (remaining <= potential_) {
-              // We can satisfy the remaining requirements for this resource type.
+              // We can satisfy the remaining requirements for this
+              // resource type.
               Resource found = remaining;
               found.set_role(potential.role());
               foundResources += found;

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/jvm/java/net.hpp
----------------------------------------------------------------------
diff --git a/src/jvm/java/net.hpp b/src/jvm/java/net.hpp
index c9c1b19..cabb3e5 100644
--- a/src/jvm/java/net.hpp
+++ b/src/jvm/java/net.hpp
@@ -6,7 +6,8 @@
 namespace java {
 namespace net {
 
-class InetSocketAddress : public Jvm::Object // TODO(benh): Extends SocketAddress.
+// TODO(benh): Extends SocketAddress.
+class InetSocketAddress : public Jvm::Object
 {
 public:
   explicit InetSocketAddress(int port)

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/jvm/org/apache/zookeeper.hpp
----------------------------------------------------------------------
diff --git a/src/jvm/org/apache/zookeeper.hpp b/src/jvm/org/apache/zookeeper.hpp
index 392e749..0797d47 100644
--- a/src/jvm/org/apache/zookeeper.hpp
+++ b/src/jvm/org/apache/zookeeper.hpp
@@ -58,7 +58,7 @@ public:
     {
       static Jvm::Constructor constructor = Jvm::get()->findConstructor(
           Jvm::Class::named(
-              "org/apache/zookeeper/server/ZooKeeperServer$BasicDataTreeBuilder")
+              "org/apache/zookeeper/server/ZooKeeperServer$BasicDataTreeBuilder") // NOLINT(whitespace/line_length)
           .constructor());
 
       object = Jvm::get()->invoke(constructor);
@@ -78,7 +78,7 @@ public:
                 "org/apache/zookeeper/server/persistence/FileTxnSnapLog"))
         .parameter(
             Jvm::Class::named(
-                "org/apache/zookeeper/server/ZooKeeperServer$DataTreeBuilder")));
+                "org/apache/zookeeper/server/ZooKeeperServer$DataTreeBuilder"))); // NOLINT(whitespace/line_length)
 
     object = Jvm::get()->invoke(
         constructor, (jobject) txnLogFactory, (jobject) treeBuilder);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/linux/cgroups.cpp
----------------------------------------------------------------------
diff --git a/src/linux/cgroups.cpp b/src/linux/cgroups.cpp
index 8202c28..8999724 100644
--- a/src/linux/cgroups.cpp
+++ b/src/linux/cgroups.cpp
@@ -1744,13 +1744,20 @@ private:
     // ignore the return values of freeze, kill, and thaw because,
     // provided there are no errors, we'll just retry the chain as
     // long as tasks still exist.
-    chain = kill(SIGSTOP)                        // Send stop signal to all tasks.
-      .then(defer(self(), &Self::kill, SIGKILL)) // Now send kill signal.
-      .then(defer(self(), &Self::empty))         // Wait until cgroup is empty.
-      .then(defer(self(), &Self::freeze))        // Freeze cgroug.
-      .then(defer(self(), &Self::kill, SIGKILL)) // Send kill signal to any remaining tasks.
-      .then(defer(self(), &Self::thaw))          // Thaw cgroup to deliver signals.
-      .then(defer(self(), &Self::empty));        // Wait until cgroup is empty.
+    // Send stop signal to all tasks.
+    chain = kill(SIGSTOP)
+      // Now send kill signal.
+      .then(defer(self(), &Self::kill, SIGKILL))
+      // Wait until cgroup is empty.
+      .then(defer(self(), &Self::empty))
+      // Freeze cgroup.
+      .then(defer(self(), &Self::freeze))
+      // Send kill signal to any remaining tasks.
+      .then(defer(self(), &Self::kill, SIGKILL))
+      // Thaw cgroup to deliver signals.
+      .then(defer(self(), &Self::thaw))
+      // Wait until cgroup is empty.
+      .then(defer(self(), &Self::empty));
 
     chain.onAny(defer(self(), &Self::finished, lambda::_1));
   }

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/log/coordinator.cpp
----------------------------------------------------------------------
diff --git a/src/log/coordinator.cpp b/src/log/coordinator.cpp
index 50b7363..fe0c5f9 100644
--- a/src/log/coordinator.cpp
+++ b/src/log/coordinator.cpp
@@ -83,7 +83,8 @@ private:
   Future<PromiseResponse> runPromisePhase();
   Future<Option<uint64_t> > checkPromisePhase(const PromiseResponse& response);
   Future<IntervalSet<uint64_t> > getMissingPositions();
-  Future<Nothing> catchupMissingPositions(const IntervalSet<uint64_t>& positions);
+  Future<Nothing> catchupMissingPositions(
+      const IntervalSet<uint64_t>& positions);
   Future<Option<uint64_t> > updateIndexAfterElected();
   void electingFinished(const Option<uint64_t>& position);
   void electingFailed();

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/logging/logging.cpp
----------------------------------------------------------------------
diff --git a/src/logging/logging.cpp b/src/logging/logging.cpp
index 176e49a..f07d223 100644
--- a/src/logging/logging.cpp
+++ b/src/logging/logging.cpp
@@ -171,8 +171,8 @@ void initialize(
   if (flags.quiet) {
     FLAGS_stderrthreshold = 3; // FATAL.
 
-    // FLAGS_stderrthreshold is ignored when logging to stderr instead of log files.
-    // Setting the minimum log level gets around this issue.
+    // FLAGS_stderrthreshold is ignored when logging to stderr instead
+    // of log files. Setting the minimum log level gets around this issue.
     if (FLAGS_logtostderr) {
       FLAGS_minloglevel = 3; // FATAL.
     }

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/master/detector.cpp
----------------------------------------------------------------------
diff --git a/src/master/detector.cpp b/src/master/detector.cpp
index 2de1fd4..ea8011f 100644
--- a/src/master/detector.cpp
+++ b/src/master/detector.cpp
@@ -65,7 +65,8 @@ public:
   ~StandaloneMasterDetectorProcess();
 
   void appoint(const Option<MasterInfo>& leader);
-  Future<Option<MasterInfo> > detect(const Option<MasterInfo>& previous = None());
+  Future<Option<MasterInfo> > detect(
+      const Option<MasterInfo>& previous = None());
 
 private:
   Option<MasterInfo> leader; // The appointed master.

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/master/flags.hpp
----------------------------------------------------------------------
diff --git a/src/master/flags.hpp b/src/master/flags.hpp
index 60606ac..3e23eca 100644
--- a/src/master/flags.hpp
+++ b/src/master/flags.hpp
@@ -200,7 +200,7 @@ public:
     add(&Flags::credentials,
         "credentials",
         "Path to a file with a list of credentials.\n"
-        "Each line contains a 'principal' and 'secret' separated by whitespace.\n"
+        "Each line contains 'principal' and 'secret' separated by whitespace.\n"
         "Path could be of the form 'file:///path/to/file' or '/path/to/file'.");
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/master/hierarchical_allocator_process.hpp
----------------------------------------------------------------------
diff --git a/src/master/hierarchical_allocator_process.hpp b/src/master/hierarchical_allocator_process.hpp
index b094fe1..0c5e2e0 100644
--- a/src/master/hierarchical_allocator_process.hpp
+++ b/src/master/hierarchical_allocator_process.hpp
@@ -262,13 +262,13 @@ public:
 
 
 template <class RoleSorter, class FrameworkSorter>
-HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::HierarchicalAllocatorProcess()
+HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::HierarchicalAllocatorProcess() // NOLINT(whitespace/line_length)
   : ProcessBase(process::ID::generate("hierarchical-allocator")),
     initialized(false) {}
 
 
 template <class RoleSorter, class FrameworkSorter>
-HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::~HierarchicalAllocatorProcess()
+HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::~HierarchicalAllocatorProcess() // NOLINT(whitespace/line_length)
 {}
 
 
@@ -276,8 +276,7 @@ template <class RoleSorter, class FrameworkSorter>
 process::PID<HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter> >
 HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::self()
 {
-  return
-    process::PID<HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter> >(this);
+  return process::PID<HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter> >(this); // NOLINT(whitespace/line_length)
 }
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/master/master.cpp
----------------------------------------------------------------------
diff --git a/src/master/master.cpp b/src/master/master.cpp
index 9baab90..c79fdaf 100644
--- a/src/master/master.cpp
+++ b/src/master/master.cpp
@@ -1471,10 +1471,10 @@ struct ResourceUsageChecker : TaskInfoVisitor
         if (!slave.hasExecutor(framework.id, task.executor().executor_id())) {
           taskResources += task.executor().resources();
           if (!((usedResources + taskResources) <= resources)) {
-            return "Task " + stringify(task.task_id()) + " + executor attempted" +
-                " to use " + stringify(taskResources) + " combined with" +
-                " already used " + stringify(usedResources) + " is greater" +
-                " than offered " + stringify(resources);
+            return "Task " + stringify(task.task_id()) +
+                   " + executor attempted to use " + stringify(taskResources) +
+                   " combined with already used " + stringify(usedResources) +
+                   " is greater than offered " + stringify(resources);
           }
         }
         executors.insert(task.executor().executor_id());

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/python/native/mesos_scheduler_driver_impl.cpp
----------------------------------------------------------------------
diff --git a/src/python/native/mesos_scheduler_driver_impl.cpp b/src/python/native/mesos_scheduler_driver_impl.cpp
index 19ce6a4..1c82532 100644
--- a/src/python/native/mesos_scheduler_driver_impl.cpp
+++ b/src/python/native/mesos_scheduler_driver_impl.cpp
@@ -146,7 +146,7 @@ PyMethodDef MesosSchedulerDriverImpl_methods[] = {
   { "reconcileTasks",
     (PyCFunction) MesosSchedulerDriverImpl_reconcileTasks,
     METH_VARARGS,
-    "Master sends status updates if task status is different from last known state."
+    "Master sends status updates if task status is different from expected"
   },
   { NULL }  /* Sentinel */
 };
@@ -198,7 +198,8 @@ int MesosSchedulerDriverImpl_init(MesosSchedulerDriverImpl* self,
   FrameworkInfo framework;
   if (frameworkObj != NULL) {
     if (!readPythonProtobuf(frameworkObj, &framework)) {
-      PyErr_Format(PyExc_Exception, "Could not deserialize Python FrameworkInfo");
+      PyErr_Format(PyExc_Exception,
+                   "Could not deserialize Python FrameworkInfo");
       return -1;
     }
   }
@@ -363,8 +364,9 @@ PyObject* MesosSchedulerDriverImpl_run(MesosSchedulerDriverImpl* self)
 }
 
 
-PyObject* MesosSchedulerDriverImpl_requestResources(MesosSchedulerDriverImpl* self,
-                                                    PyObject* args)
+PyObject* MesosSchedulerDriverImpl_requestResources(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args)
 {
   if (self->driver == NULL) {
     PyErr_Format(PyExc_Exception, "MesosSchedulerDriverImpl.driver is NULL");
@@ -379,7 +381,8 @@ PyObject* MesosSchedulerDriverImpl_requestResources(MesosSchedulerDriverImpl* se
   }
 
   if (!PyList_Check(requestsObj)) {
-    PyErr_Format(PyExc_Exception, "Parameter 2 to requestsResources is not a list");
+    PyErr_Format(PyExc_Exception,
+                 "Parameter 2 to requestsResources is not a list");
     return NULL;
   }
   Py_ssize_t len = PyList_Size(requestsObj);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/python/native/mesos_scheduler_driver_impl.hpp
----------------------------------------------------------------------
diff --git a/src/python/native/mesos_scheduler_driver_impl.hpp b/src/python/native/mesos_scheduler_driver_impl.hpp
index 9fb4867..772227e 100644
--- a/src/python/native/mesos_scheduler_driver_impl.hpp
+++ b/src/python/native/mesos_scheduler_driver_impl.hpp
@@ -83,8 +83,9 @@ int MesosSchedulerDriverImpl_clear(MesosSchedulerDriverImpl* self);
 // MesosSchedulerDriverImpl methods
 PyObject* MesosSchedulerDriverImpl_start(MesosSchedulerDriverImpl* self);
 
-PyObject* MesosSchedulerDriverImpl_stop(MesosSchedulerDriverImpl* self,
-                                        PyObject* args);
+PyObject* MesosSchedulerDriverImpl_stop(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args);
 
 PyObject* MesosSchedulerDriverImpl_abort(MesosSchedulerDriverImpl* self);
 
@@ -92,17 +93,21 @@ PyObject* MesosSchedulerDriverImpl_join(MesosSchedulerDriverImpl* self);
 
 PyObject* MesosSchedulerDriverImpl_run(MesosSchedulerDriverImpl* self);
 
-PyObject* MesosSchedulerDriverImpl_requestResources(MesosSchedulerDriverImpl* self,
-                                                    PyObject* args);
+PyObject* MesosSchedulerDriverImpl_requestResources(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args);
 
-PyObject* MesosSchedulerDriverImpl_launchTasks(MesosSchedulerDriverImpl* self,
-                                               PyObject* args);
+PyObject* MesosSchedulerDriverImpl_launchTasks(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args);
 
-PyObject* MesosSchedulerDriverImpl_killTask(MesosSchedulerDriverImpl* self,
-                                            PyObject* args);
+PyObject* MesosSchedulerDriverImpl_killTask(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args);
 
-PyObject* MesosSchedulerDriverImpl_declineOffer(MesosSchedulerDriverImpl* self,
-                                                PyObject* args);
+PyObject* MesosSchedulerDriverImpl_declineOffer(
+    MesosSchedulerDriverImpl* self,
+    PyObject* args);
 
 PyObject* MesosSchedulerDriverImpl_reviveOffers(MesosSchedulerDriverImpl* self);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/slave/containerizer/external_containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/external_containerizer.hpp b/src/slave/containerizer/external_containerizer.hpp
index eb3ff96..8fdf097 100644
--- a/src/slave/containerizer/external_containerizer.hpp
+++ b/src/slave/containerizer/external_containerizer.hpp
@@ -249,7 +249,8 @@ private:
       const Sandbox& sandbox,
       const google::protobuf::Message& message,
       const std::map<std::string, std::string>& environment =
-        (std::map<std::string, std::string>())); // Wrapped in parens due to: http://llvm.org/bugs/show_bug.cgi?id=13657
+        // Default in parens due to: http://llvm.org/bugs/show_bug.cgi?id=13657
+        (std::map<std::string, std::string>()));
 };
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/slave/containerizer/mesos_containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos_containerizer.cpp b/src/slave/containerizer/mesos_containerizer.cpp
index df57e54..71b6108 100644
--- a/src/slave/containerizer/mesos_containerizer.cpp
+++ b/src/slave/containerizer/mesos_containerizer.cpp
@@ -108,7 +108,8 @@ MesosContainerizer::~MesosContainerizer()
 }
 
 
-Future<Nothing> MesosContainerizer::recover(const Option<state::SlaveState>& state)
+Future<Nothing> MesosContainerizer::recover(
+    const Option<state::SlaveState>& state)
 {
   return dispatch(process, &MesosContainerizerProcess::recover, state);
 }

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/slave/containerizer/mesos_containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos_containerizer.hpp b/src/slave/containerizer/mesos_containerizer.hpp
index a5eb247..5353450 100644
--- a/src/slave/containerizer/mesos_containerizer.hpp
+++ b/src/slave/containerizer/mesos_containerizer.hpp
@@ -89,7 +89,8 @@ private:
 };
 
 
-class MesosContainerizerProcess : public process::Process<MesosContainerizerProcess>
+class MesosContainerizerProcess
+  : public process::Process<MesosContainerizerProcess>
 {
 public:
   MesosContainerizerProcess(

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/slave/slave.cpp
----------------------------------------------------------------------
diff --git a/src/slave/slave.cpp b/src/slave/slave.cpp
index cb80609..10619b1 100644
--- a/src/slave/slave.cpp
+++ b/src/slave/slave.cpp
@@ -377,7 +377,9 @@ void Slave::initialize()
   install("PING", &Slave::ping);
 
   // Setup HTTP routes.
-  route("/health", Http::HEALTH_HELP, lambda::bind(&Http::health, http, lambda::_1));
+  route("/health",
+        Http::HEALTH_HELP,
+        lambda::bind(&Http::health, http, lambda::_1));
   route("/stats.json", None(), lambda::bind(&Http::stats, http, lambda::_1));
   route("/state.json", None(), lambda::bind(&Http::state, http, lambda::_1));
 
@@ -2675,7 +2677,8 @@ void Slave::shutdownExecutorTimeout(
     return;
   }
 
-  if (executor->containerId != containerId) { // Make sure this timeout is valid.
+  // Make sure this timeout is valid.
+  if (executor->containerId != containerId) {
     LOG(INFO) << "A new executor '" << executorId
               << "' of framework " << frameworkId
               << " with run " << executor->containerId

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/state/zookeeper.cpp
----------------------------------------------------------------------
diff --git a/src/state/zookeeper.cpp b/src/state/zookeeper.cpp
index 689d7d1..d355bd7 100644
--- a/src/state/zookeeper.cpp
+++ b/src/state/zookeeper.cpp
@@ -457,7 +457,8 @@ Result<Option<Entry> > ZooKeeperStorageProcess::doGet(const string& name)
 }
 
 
-Result<bool> ZooKeeperStorageProcess::doSet(const Entry& entry, const UUID& uuid)
+Result<bool> ZooKeeperStorageProcess::doSet(const Entry& entry,
+                                            const UUID& uuid)
 {
   CHECK(error.isNone()) << ": " << error.get();
   CHECK(state == CONNECTED);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/allocator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/allocator_tests.cpp b/src/tests/allocator_tests.cpp
index 11ed908..6b7b097 100644
--- a/src/tests/allocator_tests.cpp
+++ b/src/tests/allocator_tests.cpp
@@ -527,8 +527,8 @@ TEST_F(ReservationAllocatorTest, ResourcesReturned)
       allocator.real, &HierarchicalDRFAllocatorProcess::slaveAdded);
 
   slave::Flags flags1 = CreateSlaveFlags();
-  flags1.resources = Option<string>("cpus(role1):1;mem(role1):200;cpus(role2):2;"
-                                    "mem(role2):600;cpus:1;mem:200;disk:0");
+  flags1.resources = Some("cpus(role1):1;mem(role1):200;cpus(role2):2;"
+                          "mem(role2):600;cpus:1;mem:200;disk:0");
   Try<PID<Slave> > slave1 = StartSlave(&exec, flags1);
   ASSERT_SOME(slave1);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/cgroups_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/cgroups_tests.cpp b/src/tests/cgroups_tests.cpp
index 6ba9de6..a051af8 100644
--- a/src/tests/cgroups_tests.cpp
+++ b/src/tests/cgroups_tests.cpp
@@ -427,7 +427,10 @@ TEST_F(CgroupsAnyHierarchyTest, ROOT_CGROUPS_Write)
 
   // In parent process.
   ASSERT_SOME(
-      cgroups::write(hierarchy, TEST_CGROUPS_ROOT, "cgroup.procs", stringify(pid)));
+      cgroups::write(hierarchy,
+                     TEST_CGROUPS_ROOT,
+                     "cgroup.procs",
+                     stringify(pid)));
 
   Try<std::set<pid_t> > pids = cgroups::processes(hierarchy, TEST_CGROUPS_ROOT);
   ASSERT_SOME(pids);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/containerizer_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer_tests.cpp b/src/tests/containerizer_tests.cpp
index 1c956bb..517859f 100644
--- a/src/tests/containerizer_tests.cpp
+++ b/src/tests/containerizer_tests.cpp
@@ -287,7 +287,8 @@ public:
   }
 
 
-  Try<MesosContainerizer*> CreateContainerizer(const Option<CommandInfo>& prepare)
+  Try<MesosContainerizer*> CreateContainerizer(
+      const Option<CommandInfo>& prepare)
   {
     vector<Option<CommandInfo> > prepares;
     prepares.push_back(prepare);
@@ -365,7 +366,8 @@ TEST_F(MesosContainerizerIsolatorPreparationTest, ScriptFails) {
   AWAIT_READY(launch);
 
   // Wait for the child (preparation script + executor) to complete.
-  Future<containerizer::Termination> wait = containerizer.get()->wait(containerId);
+  Future<containerizer::Termination> wait =
+    containerizer.get()->wait(containerId);
   AWAIT_READY(wait);
 
   // Check the child failed to exit correctly.
@@ -416,7 +418,8 @@ TEST_F(MesosContainerizerIsolatorPreparationTest, MultipleScripts) {
   AWAIT_READY(launch);
 
   // Wait for the child (preparation script(s) + executor) to complete.
-  Future<containerizer::Termination> wait = containerizer.get()->wait(containerId);
+  Future<containerizer::Termination> wait =
+    containerizer.get()->wait(containerId);
   AWAIT_READY(wait);
 
   // Check the child failed to exit correctly.

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/gc_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/gc_tests.cpp b/src/tests/gc_tests.cpp
index 95ade0f..19648fd 100644
--- a/src/tests/gc_tests.cpp
+++ b/src/tests/gc_tests.cpp
@@ -397,7 +397,8 @@ TEST_F(GarbageCollectorIntegrationTest, ExitedFramework)
     .WillOnce(FutureArg<1>(&status))
     .WillRepeatedly(Return());      // Ignore subsequent updates.
 
-  Future<Nothing> executorLaunched = FUTURE_DISPATCH(_, &Slave::executorLaunched);
+  Future<Nothing> executorLaunched =
+    FUTURE_DISPATCH(_, &Slave::executorLaunched);
 
   driver.start();
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/master_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_tests.cpp b/src/tests/master_tests.cpp
index 746668a..939a08d 100644
--- a/src/tests/master_tests.cpp
+++ b/src/tests/master_tests.cpp
@@ -624,14 +624,16 @@ TEST_F(MasterTest, MultipleExecutors)
   task1.set_name("");
   task1.mutable_task_id()->set_value("1");
   task1.mutable_slave_id()->MergeFrom(offers.get()[0].slave_id());
-  task1.mutable_resources()->MergeFrom(Resources::parse("cpus:1;mem:512").get());
+  task1.mutable_resources()->MergeFrom(
+      Resources::parse("cpus:1;mem:512").get());
   task1.mutable_executor()->MergeFrom(executor1);
 
   TaskInfo task2;
   task2.set_name("");
   task2.mutable_task_id()->set_value("2");
   task2.mutable_slave_id()->MergeFrom(offers.get()[0].slave_id());
-  task2.mutable_resources()->MergeFrom(Resources::parse("cpus:1;mem:512").get());
+  task2.mutable_resources()->MergeFrom(
+      Resources::parse("cpus:1;mem:512").get());
   task2.mutable_executor()->MergeFrom(executor2);
 
   vector<TaskInfo> tasks;

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/mesos.hpp
----------------------------------------------------------------------
diff --git a/src/tests/mesos.hpp b/src/tests/mesos.hpp
index ae14caf..335b23a 100644
--- a/src/tests/mesos.hpp
+++ b/src/tests/mesos.hpp
@@ -757,7 +757,8 @@ private:
 };
 
 
-inline const ::testing::Matcher<const std::vector<Offer>& > OfferEq(int cpus, int mem)
+inline
+const ::testing::Matcher<const std::vector<Offer>& > OfferEq(int cpus, int mem)
 {
   return MakeMatcher(new OfferEqMatcher(cpus, mem));
 }

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/resource_offers_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/resource_offers_tests.cpp b/src/tests/resource_offers_tests.cpp
index f82fa06..56682de 100644
--- a/src/tests/resource_offers_tests.cpp
+++ b/src/tests/resource_offers_tests.cpp
@@ -554,7 +554,8 @@ TEST_F(MultipleExecutorsTest, TasksExecutorInfoDiffers)
   task1.set_name("");
   task1.mutable_task_id()->set_value("1");
   task1.mutable_slave_id()->MergeFrom(offers.get()[0].slave_id());
-  task1.mutable_resources()->MergeFrom(Resources::parse("cpus:1;mem:512").get());
+  task1.mutable_resources()->MergeFrom(
+      Resources::parse("cpus:1;mem:512").get());
   task1.mutable_executor()->MergeFrom(executor);
 
   executor.mutable_command()->set_value("exit 2");
@@ -563,7 +564,8 @@ TEST_F(MultipleExecutorsTest, TasksExecutorInfoDiffers)
   task2.set_name("");
   task2.mutable_task_id()->set_value("2");
   task2.mutable_slave_id()->MergeFrom(offers.get()[0].slave_id());
-  task2.mutable_resources()->MergeFrom(Resources::parse("cpus:1;mem:512").get());
+  task2.mutable_resources()->MergeFrom(
+      Resources::parse("cpus:1;mem:512").get());
   task2.mutable_executor()->MergeFrom(executor);
 
   vector<TaskInfo> tasks;

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/resources_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/resources_tests.cpp b/src/tests/resources_tests.cpp
index 964a1b6..b5f2e8b 100644
--- a/src/tests/resources_tests.cpp
+++ b/src/tests/resources_tests.cpp
@@ -376,7 +376,8 @@ TEST(ResourcesTest, ScalarSubtraction2)
 TEST(ResourcesTest, RangesEquals)
 {
   Resource ports1 = Resources::parse("ports", "[20-40]", "*").get();
-  Resource ports2 = Resources::parse("ports", "[20-30, 31-39, 40-40]", "*").get();
+  Resource ports2 =
+    Resources::parse("ports", "[20-30, 31-39, 40-40]", "*").get();
 
   Resources r1;
   r1 += ports1;
@@ -505,7 +506,8 @@ TEST(ResourcesTest, RangesAdditon3)
 
 TEST(ResourcesTest, RangesAddition4)
 {
-  Resource ports1 = Resources::parse("ports", "[1-4, 9-10, 20-22, 26-30]", "*").get();
+  Resource ports1 =
+    Resources::parse("ports", "[1-4, 9-10, 20-22, 26-30]", "*").get();
   Resource ports2 = Resources::parse("ports", "[5-8, 23-25]", "*").get();
 
   Resources r;
@@ -523,7 +525,8 @@ TEST(ResourcesTest, RangesAddition4)
 TEST(ResourcesTest, RangesSubtraction)
 {
   Resource ports1 = Resources::parse("ports", "[20000-40000]", "*").get();
-  Resource ports2 = Resources::parse("ports", "[10000-20000, 30000-50000]", "*").get();
+  Resource ports2 =
+    Resources::parse("ports", "[10000-20000, 30000-50000]", "*").get();
 
   Resources r;
   r += ports1;
@@ -610,7 +613,8 @@ TEST(ResourcesTest, RangesSubtraction4)
 
 TEST(ResourcesTest, RangesSubtraction5)
 {
-  Resource ports1 = Resources::parse("ports", "[1-10, 20-30, 40-50]", "*").get();
+  Resource ports1 =
+    Resources::parse("ports", "[1-10, 20-30, 40-50]", "*").get();
   Resource ports2 = Resources::parse("ports", "[2-9, 15-45, 48-50]", "*").get();
 
   Resources r;
@@ -659,7 +663,8 @@ TEST(ResourcesTest, SetEquals)
 TEST(ResourcesTest, SetSubset)
 {
   Resource disks1 = Resources::parse("disks", "{sda1,sda2}", "*").get();
-  Resource disks2 = Resources::parse("disks", "{sda1,sda3,sda4,sda2}", "*").get();
+  Resource disks2 =
+    Resources::parse("disks", "{sda1,sda3,sda4,sda2}", "*").get();
 
   Resources r1;
   r1 += disks1;
@@ -677,7 +682,8 @@ TEST(ResourcesTest, SetSubset)
 TEST(ResourcesTest, SetAddition)
 {
   Resource disks1 = Resources::parse("disks", "{sda1,sda2,sda3}", "*").get();
-  Resource disks2 = Resources::parse("disks", "{sda1,sda2,sda3,sda4}", "*").get();
+  Resource disks2 =
+    Resources::parse("disks", "{sda1,sda2,sda3,sda4}", "*").get();
 
   Resources r;
   r += disks1;
@@ -693,7 +699,8 @@ TEST(ResourcesTest, SetAddition)
 
 TEST(ResourcesTest, SetSubtraction)
 {
-  Resource disks1 = Resources::parse("disks", "{sda1,sda2,sda3,sda4}", "*").get();
+  Resource disks1 =
+    Resources::parse("disks", "{sda1,sda2,sda3,sda4}", "*").get();
   Resource disks2 = Resources::parse("disks", "{sda2,sda3,sda4}", "*").get();
 
   Resources r;

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/script.cpp
----------------------------------------------------------------------
diff --git a/src/tests/script.cpp b/src/tests/script.cpp
index bf5e1e3..e5885ee 100644
--- a/src/tests/script.cpp
+++ b/src/tests/script.cpp
@@ -86,7 +86,8 @@ void execute(const string& script)
 
     // Start by cd'ing into the temporary directory.
     if (!os::chdir(directory.get())) {
-      std::cerr << "Failed to chdir to '" << directory.get() << "'" << std::endl;
+      std::cerr << "Failed to chdir to '" << directory.get() << "'"
+                << std::endl;
       abort();
     }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/slave_recovery_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/slave_recovery_tests.cpp b/src/tests/slave_recovery_tests.cpp
index 2d6b8d4..7e1c31e 100644
--- a/src/tests/slave_recovery_tests.cpp
+++ b/src/tests/slave_recovery_tests.cpp
@@ -1051,11 +1051,13 @@ TYPED_TEST(SlaveRecoveryTest, RemoveNonCheckpointingFramework)
   Offer offer = offers.get()[0];
 
   Offer offer1 = offer;
-  offer1.mutable_resources()->CopyFrom(Resources::parse("cpus:1;mem:512").get());
+  offer1.mutable_resources()->CopyFrom(
+      Resources::parse("cpus:1;mem:512").get());
   tasks.push_back(createTask(offer1, "sleep 1000")); // Long-running task
 
   Offer offer2 = offer;
-  offer2.mutable_resources()->CopyFrom(Resources::parse("cpus:1;mem:512").get());
+  offer2.mutable_resources()->CopyFrom(
+      Resources::parse("cpus:1;mem:512").get());
   tasks.push_back(createTask(offer2, "sleep 1000")); // Long-running task
 
   ASSERT_LE(Resources(offer1.resources()) + Resources(offer2.resources()),
@@ -3050,7 +3052,8 @@ TYPED_TEST(SlaveRecoveryTest, ResourceStatistics)
   // Set up so we can wait until the new slave updates the container's
   // resources (this occurs after the executor has re-registered).
   // TODO(idownes): This assumes the containerizer is a MesosContainerizer.
-  Future<Nothing> update = FUTURE_DISPATCH(_, &MesosContainerizerProcess::update);
+  Future<Nothing> update =
+    FUTURE_DISPATCH(_, &MesosContainerizerProcess::update);
 
   // Restart the slave (use same flags) with a new containerizer.
   Try<Containerizer*> containerizer2 = Containerizer::create(flags, true);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/tests/status_update_manager_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/status_update_manager_tests.cpp b/src/tests/status_update_manager_tests.cpp
index 07aa2ce..8cbfb83 100644
--- a/src/tests/status_update_manager_tests.cpp
+++ b/src/tests/status_update_manager_tests.cpp
@@ -517,7 +517,7 @@ TEST_F(StatusUpdateManagerTest, DuplicateTerminalUpdateBeforeAck)
     .WillOnce(FutureArg<1>(&status));
 
   // Drop the first ACK from the scheduler to the slave.
-  Future<StatusUpdateAcknowledgementMessage> statusUpdateAcknowledgementMessage =
+  Future<StatusUpdateAcknowledgementMessage> statusUpdateAckMessage =
     DROP_PROTOBUF(StatusUpdateAcknowledgementMessage(), _, slave.get());
 
   Future<Nothing> _statusUpdate =
@@ -531,7 +531,7 @@ TEST_F(StatusUpdateManagerTest, DuplicateTerminalUpdateBeforeAck)
 
   EXPECT_EQ(TASK_FINISHED, status.get().state());
 
-  AWAIT_READY(statusUpdateAcknowledgementMessage);
+  AWAIT_READY(statusUpdateAckMessage);
 
   // At this point the status update manager has enqueued
   // TASK_FINISHED update.
@@ -731,7 +731,7 @@ TEST_F(StatusUpdateManagerTest, DuplicateUpdateBeforeAck)
     .WillOnce(FutureArg<1>(&status));
 
   // Drop the first ACK from the scheduler to the slave.
-  Future<StatusUpdateAcknowledgementMessage> statusUpdateAcknowledgementMessage =
+  Future<StatusUpdateAcknowledgementMessage> statusUpdateAckMessage =
     DROP_PROTOBUF(StatusUpdateAcknowledgementMessage(), _, slave.get());
 
   Clock::pause();
@@ -744,7 +744,7 @@ TEST_F(StatusUpdateManagerTest, DuplicateUpdateBeforeAck)
 
   EXPECT_EQ(TASK_RUNNING, status.get().state());
 
-  AWAIT_READY(statusUpdateAcknowledgementMessage);
+  AWAIT_READY(statusUpdateAckMessage);
 
   Future<Nothing> _statusUpdate =
     FUTURE_DISPATCH(slave.get(), &Slave::_statusUpdate);

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/zookeeper/detector.cpp
----------------------------------------------------------------------
diff --git a/src/zookeeper/detector.cpp b/src/zookeeper/detector.cpp
index 1c859b7..62128a0 100644
--- a/src/zookeeper/detector.cpp
+++ b/src/zookeeper/detector.cpp
@@ -97,7 +97,8 @@ void LeaderDetectorProcess::watch(const set<Group::Membership>& expected)
 }
 
 
-void LeaderDetectorProcess::watched(const Future<set<Group::Membership> >& memberships)
+void LeaderDetectorProcess::watched(
+    const Future<set<Group::Membership> >& memberships)
 {
   CHECK(!memberships.isDiscarded());
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/src/zookeeper/group.cpp
----------------------------------------------------------------------
diff --git a/src/zookeeper/group.cpp b/src/zookeeper/group.cpp
index 3b7f974..46f638d 100644
--- a/src/zookeeper/group.cpp
+++ b/src/zookeeper/group.cpp
@@ -732,7 +732,9 @@ Try<bool> GroupProcess::cache()
     }
   }
 
-  foreachpair (int32_t sequence, Promise<bool>* cancelled, utils::copy(unowned)) {
+  foreachpair (int32_t sequence,
+               Promise<bool>* cancelled,
+               utils::copy(unowned)) {
     if (!sequences.contains(sequence)) {
       cancelled->set(false);
       unowned.erase(sequence); // Okay since iterating over a copy.

http://git-wip-us.apache.org/repos/asf/mesos/blob/f88d5dc1/support/mesos-style.py
----------------------------------------------------------------------
diff --git a/support/mesos-style.py b/support/mesos-style.py
index d404432..bd7dcdb 100755
--- a/support/mesos-style.py
+++ b/support/mesos-style.py
@@ -17,6 +17,7 @@ active_rules = ['build/class',
                 'whitespace/ending_newline',
                 'whitespace/forcolon',
                 'whitespace/indent',
+                'whitespace/line_length',
                 'whitespace/tab',
                 'whitespace/todo']
 


[3/7] git commit: Updated stout to satisfy whitespace/line_length.

Posted by be...@apache.org.
Updated stout to satisfy whitespace/line_length.

Review: https://reviews.apache.org/r/20976


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

Branch: refs/heads/master
Commit: dd0cb83728e4349a51c1452ede0f2ae6f68c5fac
Parents: c140273
Author: Benjamin Hindman <be...@gmail.com>
Authored: Thu May 1 13:23:46 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 19:25:04 2014 -0700

----------------------------------------------------------------------
 .../3rdparty/stout/include/stout/abort.hpp      | 33 +++++++++++++-------
 .../3rdparty/stout/include/stout/base64.hpp     |  2 --
 .../3rdparty/stout/include/stout/foreach.hpp    | 32 +++++++++----------
 .../3rdparty/stout/include/stout/os/sysctl.hpp  |  7 ++++-
 .../3rdparty/stout/tests/base64_tests.cpp       |  3 +-
 .../3rdparty/stout/tests/strings_tests.cpp      | 10 +++---
 6 files changed, 52 insertions(+), 35 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/include/stout/abort.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/include/stout/abort.hpp b/3rdparty/libprocess/3rdparty/stout/include/stout/abort.hpp
index d43f1b5..f20feea 100644
--- a/3rdparty/libprocess/3rdparty/stout/include/stout/abort.hpp
+++ b/3rdparty/libprocess/3rdparty/stout/include/stout/abort.hpp
@@ -48,27 +48,38 @@ struct _Abort
     // In fact, it is highly unlikely that strlen would be
     // implemented in an unsafe manner:
     // http://austingroupbugs.net/view.php?id=692
-    while (write(STDERR_FILENO, prefix, strlen(prefix)) == -1 && errno == EINTR);
+    while (write(STDERR_FILENO, prefix, strlen(prefix)) == -1 &&
+           errno == EINTR);
     while (arg0 != NULL &&
-           write(STDERR_FILENO, arg0, strlen(arg0)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg0, strlen(arg0)) == -1 &&
+           errno == EINTR);
     while (arg1 != NULL &&
-           write(STDERR_FILENO, arg1, strlen(arg1)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg1, strlen(arg1)) == -1 &&
+           errno == EINTR);
     while (arg2 != NULL &&
-           write(STDERR_FILENO, arg2, strlen(arg2)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg2, strlen(arg2)) == -1 &&
+           errno == EINTR);
     while (arg3 != NULL &&
-           write(STDERR_FILENO, arg3, strlen(arg3)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg3, strlen(arg3)) == -1 &&
+           errno == EINTR);
     while (arg4 != NULL &&
-           write(STDERR_FILENO, arg4, strlen(arg4)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg4, strlen(arg4)) == -1 &&
+           errno == EINTR);
     while (arg5 != NULL &&
-           write(STDERR_FILENO, arg5, strlen(arg5)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg5, strlen(arg5)) == -1 &&
+           errno == EINTR);
     while (arg6 != NULL &&
-           write(STDERR_FILENO, arg6, strlen(arg6)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg6, strlen(arg6)) == -1 &&
+           errno == EINTR);
     while (arg7 != NULL &&
-           write(STDERR_FILENO, arg7, strlen(arg7)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg7, strlen(arg7)) == -1 &&
+           errno == EINTR);
     while (arg8 != NULL &&
-           write(STDERR_FILENO, arg8, strlen(arg8)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg8, strlen(arg8)) == -1 &&
+           errno == EINTR);
     while (arg9 != NULL &&
-           write(STDERR_FILENO, arg9, strlen(arg9)) == -1 && errno == EINTR);
+           write(STDERR_FILENO, arg9, strlen(arg9)) == -1 &&
+           errno == EINTR);
     abort();
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/include/stout/base64.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/include/stout/base64.hpp b/3rdparty/libprocess/3rdparty/stout/include/stout/base64.hpp
index 3aeafcd..1f0944a 100644
--- a/3rdparty/libprocess/3rdparty/stout/include/stout/base64.hpp
+++ b/3rdparty/libprocess/3rdparty/stout/include/stout/base64.hpp
@@ -17,7 +17,6 @@
 #include <cctype>
 #include <string>
 
-namespace stout {
 namespace base64 {
 
 // This slightly modified base64 implementation from
@@ -126,6 +125,5 @@ std::string decode(const std::string& s)
 }
 
 } // namespace base64 {
-} // namespace stout {
 
 #endif // __STOUT_BASE64_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/include/stout/foreach.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/include/stout/foreach.hpp b/3rdparty/libprocess/3rdparty/stout/include/stout/foreach.hpp
index 428e4ba..0739d63 100644
--- a/3rdparty/libprocess/3rdparty/stout/include/stout/foreach.hpp
+++ b/3rdparty/libprocess/3rdparty/stout/include/stout/foreach.hpp
@@ -33,22 +33,22 @@ swallow_assign const ignore = swallow_assign();
 
 } // namespace __foreach__ {
 
-#define BOOST_FOREACH_PAIR(VARFIRST, VARSECOND, COL)                                                            \
-    BOOST_FOREACH_PREAMBLE()                                                                                    \
-    if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_col) = BOOST_FOREACH_CONTAIN(COL)) {} else \
-    if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_cur) = BOOST_FOREACH_BEGIN(COL)) {} else   \
-    if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_end) = BOOST_FOREACH_END(COL)) {} else     \
-    for (bool BOOST_FOREACH_ID(_foreach_continue) = true, BOOST_FOREACH_ID(_foreach_onetime) = true;            \
-              BOOST_FOREACH_ID(_foreach_continue) && !BOOST_FOREACH_DONE(COL);                                  \
-              BOOST_FOREACH_ID(_foreach_continue) ? BOOST_FOREACH_NEXT(COL) : (void)0)                          \
-        if  (boost::foreach_detail_::set_false(BOOST_FOREACH_ID(_foreach_onetime))) {} else                     \
-        for (VARFIRST = BOOST_FOREACH_DEREF(COL).first;                                                         \
-       !BOOST_FOREACH_ID(_foreach_onetime);                                                                     \
-       BOOST_FOREACH_ID(_foreach_onetime) = true)                                                               \
-            if  (boost::foreach_detail_::set_false(BOOST_FOREACH_ID(_foreach_continue))) {} else                \
-            for (VARSECOND = BOOST_FOREACH_DEREF(COL).second;                                                   \
-     !BOOST_FOREACH_ID(_foreach_continue);                                                                      \
-     BOOST_FOREACH_ID(_foreach_continue) = true)
+#define BOOST_FOREACH_PAIR(VARFIRST, VARSECOND, COL)                    \
+  BOOST_FOREACH_PREAMBLE()                                              \
+  if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_col) = BOOST_FOREACH_CONTAIN(COL)) {} else /* NOLINT(whitespace/line_length) */ \
+    if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_cur) = BOOST_FOREACH_BEGIN(COL)) {} else /* NOLINT(whitespace/line_length) */ \
+      if (boost::foreach_detail_::auto_any_t BOOST_FOREACH_ID(_foreach_end) = BOOST_FOREACH_END(COL)) {} else /* NOLINT(whitespace/line_length) */ \
+        for (bool BOOST_FOREACH_ID(_foreach_continue) = true, BOOST_FOREACH_ID(_foreach_onetime) = true; /* NOLINT(whitespace/line_length) */ \
+             BOOST_FOREACH_ID(_foreach_continue) && !BOOST_FOREACH_DONE(COL); /* NOLINT(whitespace/line_length) */ \
+             BOOST_FOREACH_ID(_foreach_continue) ? BOOST_FOREACH_NEXT(COL) : (void)0) /* NOLINT(whitespace/line_length) */ \
+          if (boost::foreach_detail_::set_false(BOOST_FOREACH_ID(_foreach_onetime))) {} else /* NOLINT(whitespace/line_length) */ \
+            for (VARFIRST = BOOST_FOREACH_DEREF(COL).first;             \
+                 !BOOST_FOREACH_ID(_foreach_onetime);                   \
+                 BOOST_FOREACH_ID(_foreach_onetime) = true)             \
+              if (boost::foreach_detail_::set_false(BOOST_FOREACH_ID(_foreach_continue))) {} else /* NOLINT(whitespace/line_length) */ \
+                for (VARSECOND = BOOST_FOREACH_DEREF(COL).second;       \
+                     !BOOST_FOREACH_ID(_foreach_continue);              \
+                     BOOST_FOREACH_ID(_foreach_continue) = true)
 
 #define foreach BOOST_FOREACH
 #define foreachpair BOOST_FOREACH_PAIR

http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/include/stout/os/sysctl.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/include/stout/os/sysctl.hpp b/3rdparty/libprocess/3rdparty/stout/include/stout/os/sysctl.hpp
index 6b04590..a1e6e4d 100644
--- a/3rdparty/libprocess/3rdparty/stout/include/stout/os/sysctl.hpp
+++ b/3rdparty/libprocess/3rdparty/stout/include/stout/os/sysctl.hpp
@@ -158,7 +158,12 @@ inline sysctl::sysctl(int level1, int level2, int level3, int level4)
 }
 
 
-inline sysctl::sysctl(int level1, int level2, int level3, int level4, int level5)
+inline sysctl::sysctl(
+    int level1,
+    int level2,
+    int level3,
+    int level4,
+    int level5)
   : levels(5), name(new int[levels])
 {
   name[0] = level1;

http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/tests/base64_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/tests/base64_tests.cpp b/3rdparty/libprocess/3rdparty/stout/tests/base64_tests.cpp
index 050cc1c..28a94f9 100644
--- a/3rdparty/libprocess/3rdparty/stout/tests/base64_tests.cpp
+++ b/3rdparty/libprocess/3rdparty/stout/tests/base64_tests.cpp
@@ -18,9 +18,10 @@
 
 TEST(Base64, Encode)
 {
-  EXPECT_EQ("dGVzdHVzZXI6dGVzdHBhc3M=", base64::encode((const unsigned char *)("testuser:testpass"), 17));
+  EXPECT_EQ("dGVzdHVzZXI6dGVzdHBhc3M=", base64::encode("testuser:testpass"));
 }
 
+
 TEST(Base64, Decode)
 {
   EXPECT_EQ("testuser:testpass", base64::decode("dGVzdHVzZXI6dGVzdHBhc3M="));

http://git-wip-us.apache.org/repos/asf/mesos/blob/dd0cb837/3rdparty/libprocess/3rdparty/stout/tests/strings_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/tests/strings_tests.cpp b/3rdparty/libprocess/3rdparty/stout/tests/strings_tests.cpp
index b5a233f..c83156e 100644
--- a/3rdparty/libprocess/3rdparty/stout/tests/strings_tests.cpp
+++ b/3rdparty/libprocess/3rdparty/stout/tests/strings_tests.cpp
@@ -98,7 +98,8 @@ TEST(StringsTest, TokenizeStringWithDelimsAtStart)
 
 TEST(StringsTest, TokenizeStringWithDelimsAtEnd)
 {
-  vector<string> tokens = strings::tokenize("hello world,  what's up?  ", " ");
+  vector<string> tokens =
+    strings::tokenize("hello world,  what's up?  ", " ");
   ASSERT_EQ(4u, tokens.size());
   EXPECT_EQ("hello",  tokens[0]);
   EXPECT_EQ("world,", tokens[1]);
@@ -109,7 +110,8 @@ TEST(StringsTest, TokenizeStringWithDelimsAtEnd)
 
 TEST(StringsTest, TokenizeStringWithDelimsAtStartAndEnd)
 {
-  vector<string> tokens = strings::tokenize("  hello world,  what's up?  ", " ");
+  vector<string> tokens =
+    strings::tokenize("  hello world,  what's up?  ", " ");
   ASSERT_EQ(4u, tokens.size());
   EXPECT_EQ("hello",  tokens[0]);
   EXPECT_EQ("world,", tokens[1]);
@@ -120,8 +122,8 @@ TEST(StringsTest, TokenizeStringWithDelimsAtStartAndEnd)
 
 TEST(StringsTest, TokenizeWithMultipleDelims)
 {
-  vector<string> tokens = strings::tokenize("hello\tworld,  \twhat's up?",
-                                            " \t");
+  vector<string> tokens =
+    strings::tokenize("hello\tworld,  \twhat's up?", " \t");
   ASSERT_EQ(4u, tokens.size());
   EXPECT_EQ("hello",  tokens[0]);
   EXPECT_EQ("world,", tokens[1]);


[4/7] git commit: Updated Mesos to satisfy whitespace/indent.

Posted by be...@apache.org.
Updated Mesos to satisfy whitespace/indent.

Also modified cpplint.py to check that access keywords are NOT
indented and enabled the cpplint rule in mesos-style.py.

Review: https://reviews.apache.org/r/21005


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

Branch: refs/heads/master
Commit: c14027334b6c83352bcf5c436cc19f997f7fb5a9
Parents: 3fa78fa
Author: Adam B <ad...@mesosphere.io>
Authored: Fri May 2 19:22:36 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 19:25:04 2014 -0700

----------------------------------------------------------------------
 src/log/coordinator.cpp                         |   2 +-
 src/log/recover.cpp                             |   2 +-
 .../native/mesos_executor_driver_impl.cpp       |  55 ++++++----
 .../native/mesos_scheduler_driver_impl.cpp      | 100 +++++++++++--------
 src/slave/state.cpp                             |   2 +-
 src/tests/master_tests.cpp                      |   2 +-
 src/tests/slave_recovery_tests.cpp              |   2 +-
 support/cpplint.patch                           |  35 +++++--
 support/cpplint.py                              |   8 +-
 support/mesos-style.py                          |   1 +
 10 files changed, 135 insertions(+), 74 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/log/coordinator.cpp
----------------------------------------------------------------------
diff --git a/src/log/coordinator.cpp b/src/log/coordinator.cpp
index 271fe89..50b7363 100644
--- a/src/log/coordinator.cpp
+++ b/src/log/coordinator.cpp
@@ -213,7 +213,7 @@ Future<Option<uint64_t> > CoordinatorProcess::checkPromisePhase(
     return getMissingPositions()
       .then(defer(self(), &Self::catchupMissingPositions, lambda::_1))
       .then(defer(self(), &Self::updateIndexAfterElected));
-   }
+  }
 }
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/log/recover.cpp
----------------------------------------------------------------------
diff --git a/src/log/recover.cpp b/src/log/recover.cpp
index 7c0566a..2013e91 100644
--- a/src/log/recover.cpp
+++ b/src/log/recover.cpp
@@ -292,7 +292,7 @@ private:
 
   void finished(const Future<Option<RecoverResponse> >& future)
   {
-   if (future.isDiscarded()) {
+    if (future.isDiscarded()) {
       // We use the boolean flag 'terminating' to distinguish between
       // a user initiated discard and a timeout induced discard. In
       // the case of a user initiated discard, the flag 'terminating'

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/python/native/mesos_executor_driver_impl.cpp
----------------------------------------------------------------------
diff --git a/src/python/native/mesos_executor_driver_impl.cpp b/src/python/native/mesos_executor_driver_impl.cpp
index a2f7607..aa564ed 100644
--- a/src/python/native/mesos_executor_driver_impl.cpp
+++ b/src/python/native/mesos_executor_driver_impl.cpp
@@ -88,25 +88,42 @@ PyTypeObject MesosExecutorDriverImplType = {
  * List of Python methods in MesosExecutorDriverImpl.
  */
 PyMethodDef MesosExecutorDriverImpl_methods[] = {
-  {"start", (PyCFunction) MesosExecutorDriverImpl_start, METH_NOARGS,
-   "Start the driver to connect to Mesos"},
-  {"stop", (PyCFunction) MesosExecutorDriverImpl_stop, METH_NOARGS,
-   "Stop the driver, disconnecting from Mesos"},
-  {"abort", (PyCFunction) MesosExecutorDriverImpl_abort, METH_NOARGS,
-   "Abort the driver, disallowing calls from and to the driver"},
-  {"join", (PyCFunction) MesosExecutorDriverImpl_join, METH_NOARGS,
-   "Wait for a running driver to disconnect from Mesos"},
-  {"run", (PyCFunction) MesosExecutorDriverImpl_run, METH_NOARGS,
-   "Start a driver and run it, returning when it disconnects from Mesos"},
-  {"sendStatusUpdate",
-   (PyCFunction) MesosExecutorDriverImpl_sendStatusUpdate,
-   METH_VARARGS,
-   "Send a status update for a task"},
-  {"sendFrameworkMessage",
-   (PyCFunction) MesosExecutorDriverImpl_sendFrameworkMessage,
-   METH_VARARGS,
-   "Send a FrameworkMessage to a slave"},
-  {NULL}  /* Sentinel */
+  { "start",
+    (PyCFunction) MesosExecutorDriverImpl_start,
+    METH_NOARGS,
+    "Start the driver to connect to Mesos"
+  },
+  { "stop",
+    (PyCFunction) MesosExecutorDriverImpl_stop,
+    METH_NOARGS,
+    "Stop the driver, disconnecting from Mesos"
+  },
+  { "abort",
+    (PyCFunction) MesosExecutorDriverImpl_abort,
+    METH_NOARGS,
+    "Abort the driver, disallowing calls from and to the driver"
+  },
+  { "join",
+    (PyCFunction) MesosExecutorDriverImpl_join,
+    METH_NOARGS,
+    "Wait for a running driver to disconnect from Mesos"
+  },
+  { "run",
+    (PyCFunction) MesosExecutorDriverImpl_run,
+    METH_NOARGS,
+    "Start a driver and run it, returning when it disconnects from Mesos"
+  },
+  { "sendStatusUpdate",
+    (PyCFunction) MesosExecutorDriverImpl_sendStatusUpdate,
+    METH_VARARGS,
+    "Send a status update for a task"
+  },
+  { "sendFrameworkMessage",
+    (PyCFunction) MesosExecutorDriverImpl_sendFrameworkMessage,
+    METH_VARARGS,
+    "Send a FrameworkMessage to a slave"
+  },
+  { NULL }  /* Sentinel */
 };
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/python/native/mesos_scheduler_driver_impl.cpp
----------------------------------------------------------------------
diff --git a/src/python/native/mesos_scheduler_driver_impl.cpp b/src/python/native/mesos_scheduler_driver_impl.cpp
index ff5c749..19ce6a4 100644
--- a/src/python/native/mesos_scheduler_driver_impl.cpp
+++ b/src/python/native/mesos_scheduler_driver_impl.cpp
@@ -88,45 +88,67 @@ PyTypeObject MesosSchedulerDriverImplType = {
  * List of Python methods in MesosSchedulerDriverImpl.
  */
 PyMethodDef MesosSchedulerDriverImpl_methods[] = {
-  {"start", (PyCFunction) MesosSchedulerDriverImpl_start, METH_NOARGS,
-   "Start the driver to connect to Mesos"},
-  {"stop", (PyCFunction) MesosSchedulerDriverImpl_stop, METH_VARARGS,
-   "Stop the driver, disconnecting from Mesos"},
-  {"abort", (PyCFunction) MesosSchedulerDriverImpl_abort, METH_NOARGS,
-    "Abort the driver, disabling calls from and to the driver"},
-  {"join", (PyCFunction) MesosSchedulerDriverImpl_join, METH_NOARGS,
-   "Wait for a running driver to disconnect from Mesos"},
-  {"run", (PyCFunction) MesosSchedulerDriverImpl_run, METH_NOARGS,
-   "Start a driver and run it, returning when it disconnects from Mesos"},
-  {"requestResources",
-   (PyCFunction) MesosSchedulerDriverImpl_requestResources,
-   METH_VARARGS,
-   "Request resources from the Mesos allocator"},
-  {"launchTasks",
-   (PyCFunction) MesosSchedulerDriverImpl_launchTasks,
-   METH_VARARGS,
-   "Reply to a Mesos offer with a list of tasks"},
-  {"killTask",
-   (PyCFunction) MesosSchedulerDriverImpl_killTask,
-   METH_VARARGS,
-   "Kill the task with the given ID"},
-  {"declineOffer",
-   (PyCFunction) MesosSchedulerDriverImpl_declineOffer,
-   METH_VARARGS,
-   "Decline a Mesos offer"},
-  {"reviveOffers",
-   (PyCFunction) MesosSchedulerDriverImpl_reviveOffers,
-   METH_NOARGS,
-   "Remove all filters and ask Mesos for new offers"},
-  {"sendFrameworkMessage",
-   (PyCFunction) MesosSchedulerDriverImpl_sendFrameworkMessage,
-   METH_VARARGS,
-   "Send a FrameworkMessage to a slave"},
-   {"reconcileTasks",
-   (PyCFunction) MesosSchedulerDriverImpl_reconcileTasks,
-   METH_VARARGS,
-   "Master sends status updates if task status is different from last known state."},
-  {NULL}  /* Sentinel */
+  { "start",
+    (PyCFunction) MesosSchedulerDriverImpl_start,
+    METH_NOARGS,
+    "Start the driver to connect to Mesos"
+  },
+  { "stop",
+    (PyCFunction) MesosSchedulerDriverImpl_stop,
+    METH_VARARGS,
+    "Stop the driver, disconnecting from Mesos"
+  },
+  { "abort",
+    (PyCFunction) MesosSchedulerDriverImpl_abort,
+    METH_NOARGS,
+    "Abort the driver, disabling calls from and to the driver"
+  },
+  { "join",
+    (PyCFunction) MesosSchedulerDriverImpl_join,
+    METH_NOARGS,
+    "Wait for a running driver to disconnect from Mesos"
+  },
+  { "run",
+    (PyCFunction) MesosSchedulerDriverImpl_run,
+    METH_NOARGS,
+    "Start a driver and run it, returning when it disconnects from Mesos"
+  },
+  { "requestResources",
+    (PyCFunction) MesosSchedulerDriverImpl_requestResources,
+    METH_VARARGS,
+    "Request resources from the Mesos allocator"
+  },
+  { "launchTasks",
+    (PyCFunction) MesosSchedulerDriverImpl_launchTasks,
+    METH_VARARGS,
+    "Reply to a Mesos offer with a list of tasks"
+  },
+  { "killTask",
+    (PyCFunction) MesosSchedulerDriverImpl_killTask,
+    METH_VARARGS,
+    "Kill the task with the given ID"
+  },
+  { "declineOffer",
+    (PyCFunction) MesosSchedulerDriverImpl_declineOffer,
+    METH_VARARGS,
+    "Decline a Mesos offer"
+  },
+  { "reviveOffers",
+    (PyCFunction) MesosSchedulerDriverImpl_reviveOffers,
+    METH_NOARGS,
+    "Remove all filters and ask Mesos for new offers"
+  },
+  { "sendFrameworkMessage",
+    (PyCFunction) MesosSchedulerDriverImpl_sendFrameworkMessage,
+    METH_VARARGS,
+    "Send a FrameworkMessage to a slave"
+  },
+  { "reconcileTasks",
+    (PyCFunction) MesosSchedulerDriverImpl_reconcileTasks,
+    METH_VARARGS,
+    "Master sends status updates if task status is different from last known state."
+  },
+  { NULL }  /* Sentinel */
 };
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/slave/state.cpp
----------------------------------------------------------------------
diff --git a/src/slave/state.cpp b/src/slave/state.cpp
index 2889245..87e9eb9 100644
--- a/src/slave/state.cpp
+++ b/src/slave/state.cpp
@@ -242,7 +242,7 @@ Try<FrameworkState> FrameworkState::recover(
         ": " + executors.error());
   }
 
-   // Recover the executors.
+  // Recover the executors.
   foreach (const string& path, executors.get()) {
     ExecutorID executorId;
     executorId.set_value(os::basename(path).get());

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/tests/master_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_tests.cpp b/src/tests/master_tests.cpp
index d407834..746668a 100644
--- a/src/tests/master_tests.cpp
+++ b/src/tests/master_tests.cpp
@@ -1142,7 +1142,7 @@ TEST_F(MasterTest, LaunchAcrossSlavesTest)
   EXPECT_EQ(2, resources1.cpus().get());
   EXPECT_EQ(Megabytes(1024), resources1.mem().get());
 
-   // Test that offers cannot span multiple slaves.
+  // Test that offers cannot span multiple slaves.
   Future<vector<Offer> > offers2;
   EXPECT_CALL(sched, resourceOffers(&driver, _))
     .WillOnce(FutureArg<1>(&offers2));

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/src/tests/slave_recovery_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/slave_recovery_tests.cpp b/src/tests/slave_recovery_tests.cpp
index 86cf12b..2d6b8d4 100644
--- a/src/tests/slave_recovery_tests.cpp
+++ b/src/tests/slave_recovery_tests.cpp
@@ -2339,7 +2339,7 @@ TYPED_TEST(SlaveRecoveryTest, SchedulerFailover)
     .WillOnce(FutureArg<1>(&offers2))
     .WillRepeatedly(Return());        // Ignore subsequent offers.
 
-   // Kill the task.
+  // Kill the task.
   driver2.killTask(task.task_id());
 
   // Wait for TASK_KILLED update.

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/support/cpplint.patch
----------------------------------------------------------------------
diff --git a/support/cpplint.patch b/support/cpplint.patch
index 63b5ae9..4f1ec66 100644
--- a/support/cpplint.patch
+++ b/support/cpplint.patch
@@ -1,5 +1,5 @@
---- support/cpplint.py	2014-03-14 14:44:03.077741545 -0700
-+++ support/cpplint.py2	2014-03-14 14:53:33.053733284 -0700
+--- support/cpplint.py.orig	2014-05-01 18:17:51.480890494 -0700
++++ support/cpplint.py	2014-05-01 18:20:52.068887876 -0700
 @@ -28,6 +28,8 @@
  # (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
  # OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
@@ -27,7 +27,30 @@
  
  def ParseNolintSuppressions(filename, raw_line, linenum, error):
    """Updates the global list of error-suppressions.
-@@ -3400,7 +3402,7 @@
+@@ -1993,11 +1995,9 @@
+       if access_match:
+         classinfo.access = access_match.group(2)
+ 
+-        # Check that access keywords are indented +1 space.  Skip this
+-        # check if the keywords are not preceded by whitespaces.
++        # Check that access keywords are not indented.
+         indent = access_match.group(1)
+-        if (len(indent) != classinfo.class_indent + 1 and
+-            Match(r'^\s*$', indent)):
++        if (len(indent) != classinfo.class_indent):
+           if classinfo.is_struct:
+             parent = 'struct ' + classinfo.name
+           else:
+@@ -2006,7 +2006,7 @@
+           if access_match.group(3):
+             slots = access_match.group(3)
+           error(filename, linenum, 'whitespace/indent', 3,
+-                '%s%s: should be indented +1 space inside %s' % (
++                '%s%s: should not be indented inside %s' % (
+                     access_match.group(2), slots, parent))
+ 
+     # Consume braces or semicolons from what's left of the line
+@@ -3400,7 +3400,7 @@
  
    # Check if the line is a header guard.
    is_header_guard = False
@@ -36,7 +59,7 @@
      cppvar = GetHeaderGuardCPPVariable(filename)
      if (line.startswith('#ifndef %s' % cppvar) or
          line.startswith('#define %s' % cppvar) or
-@@ -3867,7 +3869,7 @@
+@@ -3867,7 +3867,7 @@
      error(filename, linenum, 'runtime/init', 4,
            'You seem to be initializing a member variable with itself.')
  
@@ -45,7 +68,7 @@
      # TODO(unknown): check that 1-arg constructors are explicit.
      #                How to tell it's a constructor?
      #                (handled in CheckForNonStandardConstructs for now)
-@@ -4011,7 +4013,7 @@
+@@ -4011,7 +4011,7 @@
    # Check for use of unnamed namespaces in header files.  Registration
    # macros are typically OK, so we allow use of "namespace {" on lines
    # that end with backslashes.
@@ -54,7 +77,7 @@
        and Search(r'\bnamespace\s*{', line)
        and line[-1] != '\\'):
      error(filename, linenum, 'build/namespaces', 4,
-@@ -4552,7 +4554,7 @@
+@@ -4552,7 +4552,7 @@
  
    CheckForCopyright(filename, lines, error)
  

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/support/cpplint.py
----------------------------------------------------------------------
diff --git a/support/cpplint.py b/support/cpplint.py
index 2ad644e..90aa4ba 100644
--- a/support/cpplint.py
+++ b/support/cpplint.py
@@ -1995,11 +1995,9 @@ class _NestingState(object):
       if access_match:
         classinfo.access = access_match.group(2)
 
-        # Check that access keywords are indented +1 space.  Skip this
-        # check if the keywords are not preceded by whitespaces.
+        # Check that access keywords are not indented.
         indent = access_match.group(1)
-        if (len(indent) != classinfo.class_indent + 1 and
-            Match(r'^\s*$', indent)):
+        if (len(indent) != classinfo.class_indent):
           if classinfo.is_struct:
             parent = 'struct ' + classinfo.name
           else:
@@ -2008,7 +2006,7 @@ class _NestingState(object):
           if access_match.group(3):
             slots = access_match.group(3)
           error(filename, linenum, 'whitespace/indent', 3,
-                '%s%s: should be indented +1 space inside %s' % (
+                '%s%s: should not be indented inside %s' % (
                     access_match.group(2), slots, parent))
 
     # Consume braces or semicolons from what's left of the line

http://git-wip-us.apache.org/repos/asf/mesos/blob/c1402733/support/mesos-style.py
----------------------------------------------------------------------
diff --git a/support/mesos-style.py b/support/mesos-style.py
index 4649edb..d404432 100755
--- a/support/mesos-style.py
+++ b/support/mesos-style.py
@@ -16,6 +16,7 @@ active_rules = ['build/class',
                 'whitespace/comma',
                 'whitespace/ending_newline',
                 'whitespace/forcolon',
+                'whitespace/indent',
                 'whitespace/tab',
                 'whitespace/todo']
 


[5/7] git commit: Updated stout to satisfy whitespace/indent.

Posted by be...@apache.org.
Updated stout to satisfy whitespace/indent.

Review: https://reviews.apache.org/r/21004


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

Branch: refs/heads/master
Commit: 3fa78fa2604599645a5fc51c494acb9b31f19518
Parents: 0b87e3c
Author: Adam B <ad...@mesosphere.io>
Authored: Fri May 2 19:22:25 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 19:25:04 2014 -0700

----------------------------------------------------------------------
 3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/3fa78fa2/3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp b/3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp
index aca97ca..685a9a1 100644
--- a/3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp
+++ b/3rdparty/libprocess/3rdparty/stout/tests/linkedhashmap_tests.cpp
@@ -88,6 +88,6 @@ TEST(LinkedHashmapTest, Values)
 
   int val = 0;
   foreach (int value, map.values()) {
-   ASSERT_EQ(++val, value);
+    ASSERT_EQ(++val, value);
   }
 }


[6/7] git commit: Updated libprocess to satisfy whitespace/line_length.

Posted by be...@apache.org.
Updated libprocess to satisfy whitespace/line_length.

Review: https://reviews.apache.org/r/20977


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

Branch: refs/heads/master
Commit: 33b1a6a1fda0cfa6e15949739df655d50212a9f8
Parents: dd0cb83
Author: Benjamin Hindman <be...@gmail.com>
Authored: Thu May 1 13:25:14 2014 -0700
Committer: Benjamin Hindman <be...@gmail.com>
Committed: Fri May 2 19:25:05 2014 -0700

----------------------------------------------------------------------
 3rdparty/libprocess/3rdparty/Makefile.am        |  1 +
 3rdparty/libprocess/include/process/async.hpp   | 48 ++++++++++----------
 .../libprocess/include/process/c++11/defer.hpp  | 12 ++---
 .../include/process/c++11/deferred.hpp          | 14 +++---
 3rdparty/libprocess/include/process/future.hpp  | 28 +++++++-----
 3rdparty/libprocess/include/process/gtest.hpp   |  2 +-
 3rdparty/libprocess/include/process/help.hpp    |  2 +-
 3rdparty/libprocess/include/process/logging.hpp |  6 ++-
 3rdparty/libprocess/src/decoder.hpp             |  5 +-
 3rdparty/libprocess/src/gate.hpp                | 12 ++---
 3rdparty/libprocess/src/process.cpp             | 18 ++++++--
 3rdparty/libprocess/src/synchronized.hpp        | 11 +++--
 3rdparty/libprocess/src/tests/http_tests.cpp    |  8 +++-
 13 files changed, 96 insertions(+), 71 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/3rdparty/Makefile.am
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/Makefile.am b/3rdparty/libprocess/3rdparty/Makefile.am
index 8ccf0ef..980146b 100644
--- a/3rdparty/libprocess/3rdparty/Makefile.am
+++ b/3rdparty/libprocess/3rdparty/Makefile.am
@@ -130,6 +130,7 @@ $(RY_HTTP_PARSER)/http_parser.c: $(RY_HTTP_PARSER)-stamp
 check_PROGRAMS = stout-tests
 
 stout_tests_SOURCES =				\
+  $(STOUT)/tests/base64_tests.cpp		\
   $(STOUT)/tests/bytes_tests.cpp		\
   $(STOUT)/tests/cache_tests.cpp		\
   $(STOUT)/tests/duration_tests.cpp		\

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/async.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/async.hpp b/3rdparty/libprocess/include/process/async.hpp
index 3169985..9af3cc0 100644
--- a/3rdparty/libprocess/include/process/async.hpp
+++ b/3rdparty/libprocess/include/process/async.hpp
@@ -23,13 +23,13 @@ namespace process {
 template <typename F>
 Future<typename lambda::result_of<F(void)>::type> async(
     const F& f,
-    typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL);
+    typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL); // NOLINT(whitespace/line_length)
 
 
 template <typename F>
 Future<Nothing> async(
     const F& f,
-    typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL);
+    typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL); // NOLINT(whitespace/line_length)
 
 
 #define TEMPLATE(Z, N, DATA)                                            \
@@ -37,14 +37,14 @@ Future<Nothing> async(
   Future<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> async( \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL); \
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL); /* NOLINT(whitespace/line_length) */ \
                                                                         \
                                                                         \
   template <typename F, ENUM_PARAMS(N, typename A)>                     \
   Future<Nothing> async(                                                \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL);
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL); // NOLINT(whitespace/line_length)
 
   REPEAT_FROM_TO(1, 11, TEMPLATE, _) // Args A0 -> A9.
 #undef TEMPLATE
@@ -66,7 +66,7 @@ private:
   template <typename F>
   typename lambda::result_of<F(void)>::type execute(
       const F& f,
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL)
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL) // NOLINT(whitespace/line_length)
   {
     terminate(self()); // Terminate process after function returns.
     return f();
@@ -75,7 +75,7 @@ private:
   template <typename F>
   Nothing execute(
       const F& f,
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL)
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL) // NOLINT(whitespace/line_length)
   {
     terminate(self()); // Terminate process after function returns.
     f();
@@ -87,7 +87,7 @@ private:
   typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type execute(       \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) \
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     terminate(self()); /* Terminate process after function returns. */  \
     return f(ENUM_PARAMS(N, a));                                        \
@@ -97,7 +97,7 @@ private:
   Nothing execute(                                                      \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) \
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     terminate(self()); /* Terminate process after function returns. */  \
     f(ENUM_PARAMS(N, a));                                               \
@@ -117,25 +117,25 @@ private:
   template <typename F>
   friend Future<typename lambda::result_of<F(void)>::type> async(
       const F& f,
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*);
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*); // NOLINT(whitespace/line_length)
 
   template <typename F>
   friend Future<Nothing> async(
       const F& f,
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*);
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*); // NOLINT(whitespace/line_length)
 
 #define TEMPLATE(Z, N, DATA)                                            \
   template <typename F, ENUM_PARAMS(N, typename A)>                     \
   friend Future<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> async( \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*); \
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*); /* NOLINT(whitespace/line_length) */ \
                                                                         \
   template <typename F, ENUM_PARAMS(N, typename A)>                     \
   friend Future<Nothing> async(                                         \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*);
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*); // NOLINT(whitespace/line_length)
 
   REPEAT_FROM_TO(1, 11, TEMPLATE, _) // Args A0 -> A9.
 #undef TEMPLATE
@@ -155,10 +155,10 @@ private:
   template <typename F>
   Future<typename lambda::result_of<F(void)>::type> execute(
       const F& f,
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL)
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL) // NOLINT(whitespace/line_length)
   {
     // Need to disambiguate overloaded method.
-    typename lambda::result_of<F(void)>::type(AsyncExecutorProcess::*method)(const F&, typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) =
+    typename lambda::result_of<F(void)>::type(AsyncExecutorProcess::*method)(const F&, typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) = // NOLINT(whitespace/line_length)
       &AsyncExecutorProcess::execute<F>;
 
     return dispatch(process, method, f, (void*) NULL);
@@ -167,10 +167,10 @@ private:
   template <typename F>
   Future<Nothing> execute(
       const F& f,
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL)
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type* = NULL) // NOLINT(whitespace/line_length)
   {
     // Need to disambiguate overloaded method.
-    Nothing(AsyncExecutorProcess::*method)(const F&, typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) =
+    Nothing(AsyncExecutorProcess::*method)(const F&, typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) = // NOLINT(whitespace/line_length)
       &AsyncExecutorProcess::execute<F>;
 
     return dispatch(process, method, f, (void*) NULL);
@@ -181,10 +181,10 @@ private:
   Future<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> execute( \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) \
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     /* Need to disambiguate overloaded method. */                       \
-    typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type(AsyncExecutorProcess::*method)(const F&, ENUM_PARAMS(N, A), typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) = \
+    typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type(AsyncExecutorProcess::*method)(const F&, ENUM_PARAMS(N, A), typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) = /* NOLINT(whitespace/line_length) */ \
       &AsyncExecutorProcess::execute<F, ENUM_PARAMS(N, A)>;             \
                                                                         \
     return dispatch(process, method, f, ENUM_PARAMS(N, a), (void*) NULL); \
@@ -194,10 +194,10 @@ private:
   Future<Nothing> execute(                                              \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) \
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type* = NULL) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     /* Need to disambiguate overloaded method. */                       \
-    Nothing(AsyncExecutorProcess::*method)(const F&, ENUM_PARAMS(N, A), typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) = \
+    Nothing(AsyncExecutorProcess::*method)(const F&, ENUM_PARAMS(N, A), typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) = /* NOLINT(whitespace/line_length) */ \
       &AsyncExecutorProcess::execute<F, ENUM_PARAMS(N, A)>;             \
                                                                         \
     return dispatch(process, method, f, ENUM_PARAMS(N, a), (void*) NULL); \
@@ -214,7 +214,7 @@ private:
 template <typename F>
 Future<typename lambda::result_of<F(void)>::type> async(
     const F& f,
-    typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*)
+    typename boost::disable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) // NOLINT(whitespace/line_length)
 {
   return AsyncExecutor().execute(f);
 }
@@ -223,7 +223,7 @@ Future<typename lambda::result_of<F(void)>::type> async(
 template <typename F>
 Future<Nothing> async(
     const F& f,
-    typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*)
+    typename boost::enable_if<boost::is_void<typename lambda::result_of<F(void)>::type> >::type*) // NOLINT(whitespace/line_length)
 {
   return AsyncExecutor().execute(f);
 }
@@ -234,7 +234,7 @@ Future<Nothing> async(
   Future<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> async( \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) \
+      typename boost::disable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     return AsyncExecutor().execute(f, ENUM_PARAMS(N, a));               \
   }                                                                     \
@@ -243,7 +243,7 @@ Future<Nothing> async(
   Future<Nothing> async(                                                \
       const F& f,                                                       \
       ENUM_BINARY_PARAMS(N, A, a),                                      \
-      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) \
+      typename boost::enable_if<boost::is_void<typename lambda::result_of<F(ENUM_PARAMS(N, A))>::type> >::type*) /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     return AsyncExecutor().execute(f, ENUM_PARAMS(N, a));               \
   }

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/c++11/defer.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/c++11/defer.hpp b/3rdparty/libprocess/include/process/c++11/defer.hpp
index de041ad..7b4dd07 100644
--- a/3rdparty/libprocess/include/process/c++11/defer.hpp
+++ b/3rdparty/libprocess/include/process/c++11/defer.hpp
@@ -61,13 +61,13 @@ Deferred<void(void)> defer(
   auto defer(const PID<T>& pid,                                         \
              void (T::*method)(ENUM_PARAMS(N, P)),                      \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::function<void(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> \
+    -> _Deferred<decltype(std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::function<void(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     std::function<void(ENUM_PARAMS(N, P))> f(                           \
         [=] (ENUM_BINARY_PARAMS(N, P, p)) {                             \
           dispatch(pid, method, ENUM_PARAMS(N, p));                     \
         });                                                             \
-    return std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); \
+    return std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); /* NOLINT(whitespace/line_length) */ \
   }                                                                     \
                                                                         \
   template <typename T,                                                 \
@@ -129,13 +129,13 @@ defer(const Process<T>* process, Future<R> (T::*method)(void))
   auto defer(const PID<T>& pid,                                         \
              Future<R> (T::*method)(ENUM_PARAMS(N, P)),                 \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> \
+    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     std::function<Future<R>(ENUM_PARAMS(N, P))> f(                      \
         [=] (ENUM_BINARY_PARAMS(N, P, p)) {                             \
           return dispatch(pid, method, ENUM_PARAMS(N, p));              \
         });                                                             \
-    return std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); \
+    return std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); /* NOLINT(whitespace/line_length) */ \
   }                                                                     \
                                                                         \
   template <typename R,                                                 \
@@ -199,13 +199,13 @@ defer(const Process<T>* process, R (T::*method)(void))
   auto defer(const PID<T>& pid,                                         \
              R (T::*method)(ENUM_PARAMS(N, P)),                         \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> \
+    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))> /* NOLINT(whitespace/line_length) */ \
   {                                                                     \
     std::function<Future<R>(ENUM_PARAMS(N, P))> f(                      \
         [=] (ENUM_BINARY_PARAMS(N, P, p)) {                             \
           return dispatch(pid, method, ENUM_PARAMS(N, p));              \
         });                                                             \
-    return std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); \
+    return std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::move(f), ENUM_PARAMS(N, a)); /* NOLINT(whitespace/line_length) */ \
   }                                                                     \
                                                                         \
   template <typename R,                                                 \

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/c++11/deferred.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/c++11/deferred.hpp b/3rdparty/libprocess/include/process/c++11/deferred.hpp
index 4a25e12..352205b 100644
--- a/3rdparty/libprocess/include/process/c++11/deferred.hpp
+++ b/3rdparty/libprocess/include/process/c++11/deferred.hpp
@@ -137,7 +137,7 @@ struct _Deferred
       return std::function<void(ENUM_PARAMS(N, P))>(f);                 \
     }                                                                   \
                                                                         \
-    Option<UPID> pid_ = pid;                                                    \
+    Option<UPID> pid_ = pid;                                            \
     F f_ = f;                                                           \
                                                                         \
     return std::function<void(ENUM_PARAMS(N, P))>(                      \
@@ -156,7 +156,7 @@ struct _Deferred
       return std::function<void(ENUM_PARAMS(N, P))>(f);                 \
     }                                                                   \
                                                                         \
-    Option<UPID> pid_ = pid;                                                    \
+    Option<UPID> pid_ = pid;                                            \
     F f_ = f;                                                           \
                                                                         \
     return std::function<void(ENUM_PARAMS(N, P))>(                      \
@@ -179,7 +179,7 @@ struct _Deferred
       return std::function<R(ENUM_PARAMS(N, P))>(f);                    \
     }                                                                   \
                                                                         \
-    Option<UPID> pid_ = pid;                                                    \
+    Option<UPID> pid_ = pid;                                            \
     F f_ = f;                                                           \
                                                                         \
     return std::function<R(ENUM_PARAMS(N, P))>(                         \
@@ -198,7 +198,7 @@ struct _Deferred
       return std::function<R(ENUM_PARAMS(N, P))>(f);                    \
     }                                                                   \
                                                                         \
-    Option<UPID> pid_ = pid;                                                    \
+    Option<UPID> pid_ = pid;                                            \
     F f_ = f;                                                           \
                                                                         \
     return std::function<R(ENUM_PARAMS(N, P))>(                         \
@@ -226,7 +226,7 @@ private:
   friend auto defer(const PID<T>& pid,                                  \
              void (T::*method)(ENUM_PARAMS(N, P)),                      \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::function<void(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>;
+    -> _Deferred<decltype(std::bind(&std::function<void(ENUM_PARAMS(N, P))>::operator(), std::function<void(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>; // NOLINT(whitespace/line_length)
 
   REPEAT_FROM_TO(1, 11, TEMPLATE, _) // Args A0 -> A9.
 #undef TEMPLATE
@@ -239,7 +239,7 @@ private:
   friend auto defer(const PID<T>& pid,                                  \
              Future<R> (T::*method)(ENUM_PARAMS(N, P)),                 \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>;
+    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>; // NOLINT(whitespace/line_length)
 
   REPEAT_FROM_TO(1, 11, TEMPLATE, _) // Args A0 -> A9.
 #undef TEMPLATE
@@ -252,7 +252,7 @@ private:
   friend auto defer(const PID<T>& pid,                                  \
              R (T::*method)(ENUM_PARAMS(N, P)),                         \
              ENUM_BINARY_PARAMS(N, A, a))                               \
-    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>;
+    -> _Deferred<decltype(std::bind(&std::function<Future<R>(ENUM_PARAMS(N, P))>::operator(), std::function<Future<R>(ENUM_PARAMS(N, P))>(), ENUM_PARAMS(N, a)))>; // NOLINT(whitespace/line_length)
 
   REPEAT_FROM_TO(1, 11, TEMPLATE, _) // Args A0 -> A9.
 #undef TEMPLATE

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/future.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/future.hpp b/3rdparty/libprocess/include/process/future.hpp
index 8bbd14d..5b0ed9b 100644
--- a/3rdparty/libprocess/include/process/future.hpp
+++ b/3rdparty/libprocess/include/process/future.hpp
@@ -222,7 +222,7 @@ private:
         }));
   }
 
-  template <typename F, typename = typename std::result_of<F(const std::string&)>::type>
+  template <typename F, typename = typename std::result_of<F(const std::string&)>::type> // NOLINT(whitespace/line_length)
   const Future<T>& onFailed(F&& f, Prefer) const
   {
     return onFailed(std::function<void(const std::string&)>(
@@ -240,7 +240,7 @@ private:
         }));
   }
 
-  template <typename F, typename = typename std::result_of<F(const Future<T>&)>::type>
+  template <typename F, typename = typename std::result_of<F(const Future<T>&)>::type> // NOLINT(whitespace/line_length)
   const Future<T>& onAny(F&& f, Prefer) const
   {
     return onAny(std::function<void(const Future<T>&)>(
@@ -329,7 +329,7 @@ public:
 
 #if __cplusplus >= 201103L
 private:
-  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F(const T&)>::type>::type>
+  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F(const T&)>::type>::type> // NOLINT(whitespace/line_length)
   Future<X> then(_Deferred<F>&& f, Prefer) const
   {
     // note the then<X> is necessary to not have an infinite loop with
@@ -337,19 +337,19 @@ private:
     return then<X>(std::function<Future<X>(const T&)>(f));
   }
 
-  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F()>::type>::type>
+  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F()>::type>::type> // NOLINT(whitespace/line_length)
   Future<X> then(_Deferred<F>&& f, LessPrefer) const
   {
     return then<X>(std::function<Future<X>()>(f));
   }
 
-  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F(const T&)>::type>::type>
+  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F(const T&)>::type>::type> // NOLINT(whitespace/line_length)
   Future<X> then(F&& f, Prefer) const
   {
     return then<X>(std::function<Future<X>(const T&)>(f));
   }
 
-  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F()>::type>::type>
+  template <typename F, typename X = typename internal::unwrap<typename std::result_of<F()>::type>::type> // NOLINT(whitespace/line_length)
   Future<X> then(F&& f, LessPrefer) const
   {
     return then<X>(std::function<Future<X>()>(f));
@@ -479,7 +479,7 @@ public:
   Future<T> after(
       const Duration& duration,
       _Deferred<F>&& f,
-      typename std::enable_if<std::is_convertible<_Deferred<F>, std::function<Future<T>(const Future<T>&)>>::value>::type* = NULL) const
+      typename std::enable_if<std::is_convertible<_Deferred<F>, std::function<Future<T>(const Future<T>&)>>::value>::type* = NULL) const // NOLINT(whitespace/line_length)
   {
     return after(duration, std::function<Future<T>(const Future<T>&)>(f));
   }
@@ -488,16 +488,18 @@ public:
   Future<T> after(
       const Duration& duration,
       _Deferred<F>&& f,
-      typename std::enable_if<std::is_convertible<_Deferred<F>, std::function<Future<T>()>>::value>::type* = NULL) const
+      typename std::enable_if<std::is_convertible<_Deferred<F>, std::function<Future<T>()>>::value>::type* = NULL) const // NOLINT(whitespace/line_length)
   {
-    return after(duration, std::function<Future<T>(const Future<T>&)>(std::bind(f)));
+    return after(
+        duration,
+        std::function<Future<T>(const Future<T>&)>(std::bind(f)));
   }
 #else
   template <typename F>
   Future<T> after(
       const Duration& duration,
       const _Defer<F>& f,
-      typename boost::enable_if<boost::is_convertible<_Defer<F>, std::tr1::function<Future<T>(const Future<T>&)> > >::type* = NULL) const
+      typename boost::enable_if<boost::is_convertible<_Defer<F>, std::tr1::function<Future<T>(const Future<T>&)> > >::type* = NULL) const // NOLINT(whitespace/line_length)
   {
     return after(duration, std::tr1::function<Future<T>(const Future<T>&)>(f));
   }
@@ -506,9 +508,11 @@ public:
   Future<T> after(
       const Duration& duration,
       const _Defer<F>& f,
-      typename boost::enable_if<boost::is_convertible<_Defer<F>, std::tr1::function<Future<T>()> > >::type* = NULL) const
+      typename boost::enable_if<boost::is_convertible<_Defer<F>, std::tr1::function<Future<T>()> > >::type* = NULL) const // NOLINT(whitespace/line_length)
   {
-    return after(duration, std::tr1::function<Future<T>(const Future<T>&)>(std::tr1::bind(f)));
+    return after(
+        duration,
+        std::tr1::function<Future<T>(const Future<T>&)>(std::tr1::bind(f)));
   }
 #endif // __cplusplus >= 201103L
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/gtest.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/gtest.hpp b/3rdparty/libprocess/include/process/gtest.hpp
index 11db008..b77e2fc 100644
--- a/3rdparty/libprocess/include/process/gtest.hpp
+++ b/3rdparty/libprocess/include/process/gtest.hpp
@@ -371,7 +371,7 @@ inline ::testing::AssertionResult AwaitAssertResponseHeaderEq(
 
 
 #define AWAIT_EXPECT_RESPONSE_HEADER_EQ_FOR(expected, key, actual, duration) \
-  EXPECT_PRED_FORMAT4(AwaitAssertResponseHeaderEq, expected, key, actual, duration)
+  EXPECT_PRED_FORMAT4(AwaitAssertResponseHeaderEq, expected, key, actual, duration) // NOLINT(whitespace/line_length)
 
 
 #define AWAIT_EXPECT_RESPONSE_HEADER_EQ(expected, key, actual)          \

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/help.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/help.hpp b/3rdparty/libprocess/include/process/help.hpp
index 8d50419..4333b5b 100644
--- a/3rdparty/libprocess/include/process/help.hpp
+++ b/3rdparty/libprocess/include/process/help.hpp
@@ -243,7 +243,7 @@ private:
         "  * Copyright (c) 2011-2013, Christopher Jeffrey. (MIT Licensed)"
         "  * https://github.com/chjj/marked"
         "  */"
-        "  (function(){var d={newline:/^\\n+/,code:/^( {4}[^\\n]+\\n*)+/,fences:j,hr:/^( *[-*_]){3,} *(?:\\n+|$)/,heading:/^ *(#{1,6}) *([^\\n]+?) *#* *(?:\\n+|$)/,nptable:j,lheading:/^([^\\n]+)\\n *(=|-){2,} *(?:\\n+|$)/,blockquote:/^( *>[^\\n]+(\\n[^\\n]+)*\\n*)+/,list:/^( *)(bull) [\\s\\S]+?(?:hr|\\n{2,}(?! )(?!\\1bull )\\n*|\\s*$)/,html:/^ *(?:comment|closed|closing) *(?:\\n{2,}|\\s*$)/,def:/^ *\\[([^\\]]+)\\]: *<?([^\\s>]+)>?(?: +[\"(]([^\\n]+)[\")])? *(?:\\n+|$)/,table:j,paragraph:/^((?:[^\\n]+\\n?(?!hr|heading|lheading|blockquote|tag|def))+)\\n*/,text:/^[^\\n]+/};d.bullet=/(?:[*+-]|\\d+\\.)/;d.item=/^( *)(bull) [^\\n]*(?:\\n(?!\\1bull )[^\\n]*)*/;d.item=c(d.item,\"gm\")(/bull/g,d.bullet)();d.list=c(d.list)(/bull/g,d.bullet)(\"hr\",/\\n+(?=(?: *[-*_]){3,} *(?:\\n+|$))/)();d._tag=\"(?!(?:a|em|strong|small|s|cite|q|dfn|abbr|data|time|code|var|samp|kbd|sub|sup|i|b|u|mark|ruby|rt|rp|bdi|bdo|span|br|wbr|ins|del|img)\\\\b)\\\\w+(?!:/|@)\\\\b\";d.html=c(d.html)(\"comment\",/<!--[\\s\
 \S]*?-->/)(\"closed\",/<(tag)[\\s\\S]+?<\\/\\1>/)(\"closing\",/<tag(?:\"[^\"]*\"|'[^']*'|[^'\">])*?>/)(/tag/g,d._tag)();d.paragraph=c(d.paragraph)(\"hr\",d.hr)(\"heading\",d.heading)(\"lheading\",d.lheading)(\"blockquote\",d.blockquote)(\"tag\",\"<\"+d._tag)(\"def\",d.def)();d.normal=g({},d);d.gfm=g({},d.normal,{fences:/^ *(`{3,}|~{3,}) *(\\S+)? *\\n([\\s\\S]+?)\\s*\\1 *(?:\\n+|$)/,paragraph:/^/});d.gfm.paragraph=c(d.paragraph)(\"(?!\",\"(?!\"+d.gfm.fences.source.replace(\"\\\\1\",\"\\\\2\")+\"|\"+d.list.source.replace(\"\\\\1\",\"\\\\3\")+\"|\")();d.tables=g({},d.gfm,{nptable:/^ *(\\S.*\\|.*)\\n *([-:]+ *\\|[-| :]*)\\n((?:.*\\|.*(?:\\n|$))*)\\n*/,table:/^ *\\|(.+)\\n *\\|( *[-:]+[-| :]*)\\n((?: *\\|.*(?:\\n|$))*)\\n*/});function b(k){this.tokens=[];this.tokens.links={};this.options=k||a.defaults;this.rules=d.normal;if(this.options.gfm){if(this.options.tables){this.rules=d.tables}else{this.rules=d.gfm}}}b.rules=d;b.lex=function(m,k){var l=new b(k);return l.lex(m)};b.prototype.lex=fu
 nction(k){k=k.replace(/\\r\\n|\\r/g,\"\\n\").replace(/\\t/g,\"    \").replace(/\\u00a0/g,\" \").replace(/\\u2424/g,\"\\n\");return this.token(k,true)};b.prototype.token=function(m,s){var m=m.replace(/^ +$/gm,\"\"),q,o,u,r,t,v,k,p,n;while(m){if(u=this.rules.newline.exec(m)){m=m.substring(u[0].length);if(u[0].length>1){this.tokens.push({type:\"space\"})}}if(u=this.rules.code.exec(m)){m=m.substring(u[0].length);u=u[0].replace(/^ {4}/gm,\"\");this.tokens.push({type:\"code\",text:!this.options.pedantic?u.replace(/\\n+$/,\"\"):u});continue}if(u=this.rules.fences.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"code\",lang:u[2],text:u[3]});continue}if(u=this.rules.heading.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"heading\",depth:u[1].length,text:u[2]});continue}if(s&&(u=this.rules.nptable.exec(m))){m=m.substring(u[0].length);v={type:\"table\",header:u[1].replace(/^ *| *\\| *$/g,\"\").split(/ *\\| */),align:u[2].replace(/^ *|\\| *$/g,\"\").split(/ *\\| */),cel
 ls:u[3].replace(/\\n$/,\"\").split(\"\\n\")};for(p=0;p<v.align.length;p++){if(/^ *-+: *$/.test(v.align[p])){v.align[p]=\"right\"}else{if(/^ *:-+: *$/.test(v.align[p])){v.align[p]=\"center\"}else{if(/^ *:-+ *$/.test(v.align[p])){v.align[p]=\"left\"}else{v.align[p]=null}}}}for(p=0;p<v.cells.length;p++){v.cells[p]=v.cells[p].split(/ *\\| */)}this.tokens.push(v);continue}if(u=this.rules.lheading.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"heading\",depth:u[2]===\"=\"?1:2,text:u[1]});continue}if(u=this.rules.hr.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"hr\"});continue}if(u=this.rules.blockquote.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"blockquote_start\"});u=u[0].replace(/^ *> ?/gm,\"\");this.token(u,s);this.tokens.push({type:\"blockquote_end\"});continue}if(u=this.rules.list.exec(m)){m=m.substring(u[0].length);r=u[2];this.tokens.push({type:\"list_start\",ordered:r.length>1});u=u[0].match(this.rules.item);q=false;n=u.length;p=0;for(;
 p<n;p++){v=u[p];k=v.length;v=v.replace(/^ *([*+-]|\\d+\\.) +/,\"\");if(~v.indexOf(\"\\n \")){k-=v.length;v=!this.options.pedantic?v.replace(new RegExp(\"^ {1,\"+k+\"}\",\"gm\"),\"\"):v.replace(/^ {1,4}/gm,\"\")}if(this.options.smartLists&&p!==n-1){t=d.bullet.exec(u[p+1])[0];if(r!==t&&!(r.length>1&&t.length>1)){m=u.slice(p+1).join(\"\\n\")+m;p=n-1}}o=q||/\\n\\n(?!\\s*$)/.test(v);if(p!==n-1){q=v.charAt(v.length-1)===\"\\n\";if(!o){o=q}}this.tokens.push({type:o?\"loose_item_start\":\"list_item_start\"});this.token(v,false);this.tokens.push({type:\"list_item_end\"})}this.tokens.push({type:\"list_end\"});continue}if(u=this.rules.html.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:this.options.sanitize?\"paragraph\":\"html\",pre:u[1]===\"pre\"||u[1]===\"script\"||u[1]===\"style\",text:u[0]});continue}if(s&&(u=this.rules.def.exec(m))){m=m.substring(u[0].length);this.tokens.links[u[1].toLowerCase()]={href:u[2],title:u[3]};continue}if(s&&(u=this.rules.table.exec(m))){m=m.substrin
 g(u[0].length);v={type:\"table\",header:u[1].replace(/^ *| *\\| *$/g,\"\").split(/ *\\| */),align:u[2].replace(/^ *|\\| *$/g,\"\").split(/ *\\| */),cells:u[3].replace(/(?: *\\| *)?\\n$/,\"\").split(\"\\n\")};for(p=0;p<v.align.length;p++){if(/^ *-+: *$/.test(v.align[p])){v.align[p]=\"right\"}else{if(/^ *:-+: *$/.test(v.align[p])){v.align[p]=\"center\"}else{if(/^ *:-+ *$/.test(v.align[p])){v.align[p]=\"left\"}else{v.align[p]=null}}}}for(p=0;p<v.cells.length;p++){v.cells[p]=v.cells[p].replace(/^ *\\| *| *\\| *$/g,\"\").split(/ *\\| */)}this.tokens.push(v);continue}if(s&&(u=this.rules.paragraph.exec(m))){m=m.substring(u[0].length);this.tokens.push({type:\"paragraph\",text:u[1].charAt(u[1].length-1)===\"\\n\"?u[1].slice(0,-1):u[1]});continue}if(u=this.rules.text.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"text\",text:u[0]});continue}if(m){throw new Error(\"Infinite loop on byte: \"+m.charCodeAt(0))}}return this.tokens};var f={escape:/^\\\\([\\\\`*{}\\[\\]()#+\\-.!_>])/,a
 utolink:/^<([^ >]+(@|:\\/)[^ >]+)>/,url:j,tag:/^<!--[\\s\\S]*?-->|^<\\/?\\w+(?:\"[^\"]*\"|'[^']*'|[^'\">])*?>/,link:/^!?\\[(inside)\\]\\(href\\)/,reflink:/^!?\\[(inside)\\]\\s*\\[([^\\]]*)\\]/,nolink:/^!?\\[((?:\\[[^\\]]*\\]|[^\\[\\]])*)\\]/,strong:/^__([\\s\\S]+?)__(?!_)|^\\*\\*([\\s\\S]+?)\\*\\*(?!\\*)/,em:/^\\b_((?:__|[\\s\\S])+?)_\\b|^\\*((?:\\*\\*|[\\s\\S])+?)\\*(?!\\*)/,code:/^(`+)\\s*([\\s\\S]*?[^`])\\s*\\1(?!`)/,br:/^ {2,}\\n(?!\\s*$)/,del:j,text:/^[\\s\\S]+?(?=[\\\\<!\\[_*`]| {2,}\\n|$)/};f._inside=/(?:\\[[^\\]]*\\]|[^\\[\\]]|\\](?=[^\\[]*\\]))*/;f._href=/\\s*<?([\\s\\S]*?)>?(?:\\s+['\"]([\\s\\S]*?)['\"])?\\s*/;f.link=c(f.link)(\"inside\",f._inside)(\"href\",f._href)();f.reflink=c(f.reflink)(\"inside\",f._inside)();f.normal=g({},f);f.pedantic=g({},f.normal,{strong:/^__(?=\\S)([\\s\\S]*?\\S)__(?!_)|^\\*\\*(?=\\S)([\\s\\S]*?\\S)\\*\\*(?!\\*)/,em:/^_(?=\\S)([\\s\\S]*?\\S)_(?!_)|^\\*(?=\\S)([\\s\\S]*?\\S)\\*(?!\\*)/});f.gfm=g({},f.normal,{escape:c(f.escape)(\"])\",\"~|])\")(),u
 rl:/^(https?:\\/\\/[^\\s<]+[^<.,:;\"')\\]\\s])/,del:/^~~(?=\\S)([\\s\\S]*?\\S)~~/,text:c(f.text)(\"]|\",\"~]|\")(\"|\",\"|https?://|\")()});f.breaks=g({},f.gfm,{br:c(f.br)(\"{2,}\",\"*\")(),text:c(f.gfm.text)(\"{2,}\",\"*\")()});function h(k,l){this.options=l||a.defaults;this.links=k;this.rules=f.normal;if(!this.links){throw new Error(\"Tokens array requires a `links` property.\")}if(this.options.gfm){if(this.options.breaks){this.rules=f.breaks}else{this.rules=f.gfm}}else{if(this.options.pedantic){this.rules=f.pedantic}}}h.rules=f;h.output=function(n,k,l){var m=new h(k,l);return m.output(n)};h.prototype.output=function(p){var l=\"\",n,o,k,m;while(p){if(m=this.rules.escape.exec(p)){p=p.substring(m[0].length);l+=m[1];continue}if(m=this.rules.autolink.exec(p)){p=p.substring(m[0].length);if(m[2]===\"@\"){o=m[1].charAt(6)===\":\"?this.mangle(m[1].substring(7)):this.mangle(m[1]);k=this.mangle(\"mailto:\")+o}else{o=i(m[1]);k=o}l+='<a href=\"'+k+'\">'+o+\"</a>\";continue}if(m=this.rules.url
 .exec(p)){p=p.substring(m[0].length);o=i(m[1]);k=o;l+='<a href=\"'+k+'\">'+o+\"</a>\";continue}if(m=this.rules.tag.exec(p)){p=p.substring(m[0].length);l+=this.options.sanitize?i(m[0]):m[0];continue}if(m=this.rules.link.exec(p)){p=p.substring(m[0].length);l+=this.outputLink(m,{href:m[2],title:m[3]});continue}if((m=this.rules.reflink.exec(p))||(m=this.rules.nolink.exec(p))){p=p.substring(m[0].length);n=(m[2]||m[1]).replace(/\\s+/g,\" \");n=this.links[n.toLowerCase()];if(!n||!n.href){l+=m[0].charAt(0);p=m[0].substring(1)+p;continue}l+=this.outputLink(m,n);continue}if(m=this.rules.strong.exec(p)){p=p.substring(m[0].length);l+=\"<strong>\"+this.output(m[2]||m[1])+\"</strong>\";continue}if(m=this.rules.em.exec(p)){p=p.substring(m[0].length);l+=\"<em>\"+this.output(m[2]||m[1])+\"</em>\";continue}if(m=this.rules.code.exec(p)){p=p.substring(m[0].length);l+=\"<code>\"+i(m[2],true)+\"</code>\";continue}if(m=this.rules.br.exec(p)){p=p.substring(m[0].length);l+=\"<br>\";continue}if(m=this.rules.
 del.exec(p)){p=p.substring(m[0].length);l+=\"<del>\"+this.output(m[1])+\"</del>\";continue}if(m=this.rules.text.exec(p)){p=p.substring(m[0].length);l+=i(this.smartypants(m[0]));continue}if(p){throw new Error(\"Infinite loop on byte: \"+p.charCodeAt(0))}}return l};h.prototype.outputLink=function(k,l){if(k[0].charAt(0)!==\"!\"){return'<a href=\"'+i(l.href)+'\"'+(l.title?' title=\"'+i(l.title)+'\"':\"\")+\">\"+this.output(k[1])+\"</a>\"}else{return'<img src=\"'+i(l.href)+'\" alt=\"'+i(k[1])+'\"'+(l.title?' title=\"'+i(l.title)+'\"':\"\")+\">\"}};h.prototype.smartypants=function(k){if(!this.options.smartypants){return k}return k.replace(/--/g,\"\\u2014\").replace(/(^|[-\\u2014/(\\[{\"\\s])'/g,\"$1\\u2018\").replace(/'/g,\"\\u2019\").replace(/(^|[-\\u2014/(\\[{\\u2018\\s])\"/g,\"$1\\u201c\").replace(/\"/g,\"\\u201d\").replace(/\\.{3}/g,\"\\u2026\")};h.prototype.mangle=function(p){var m=\"\",k=p.length,n=0,o;for(;n<k;n++){o=p.charCodeAt(n);if(Math.random()>0.5){o=\"x\"+o.toString(16)}m+=\
 "&#\"+o+\";\"}return m};function e(k){this.tokens=[];this.token=null;this.options=k||a.defaults}e.parse=function(l,k){var m=new e(k);return m.parse(l)};e.prototype.parse=function(l){this.inline=new h(l.links,this.options);this.tokens=l.reverse();var k=\"\";while(this.next()){k+=this.tok()}return k};e.prototype.next=function(){return this.token=this.tokens.pop()};e.prototype.peek=function(){return this.tokens[this.tokens.length-1]||0};e.prototype.parseText=function(){var k=this.token.text;while(this.peek().type===\"text\"){k+=\"\\n\"+this.next().text}return this.inline.output(k)};e.prototype.tok=function(){switch(this.token.type){case\"space\":return\"\";case\"hr\":return\"<hr>\\n\";case\"heading\":return\"<h\"+this.token.depth+' id=\"'+this.token.text.toLowerCase().replace(/[^\\w]+/g,\"-\")+'\">'+this.inline.output(this.token.text)+\"</h\"+this.token.depth+\">\\n\";case\"code\":if(this.options.highlight){var p=this.options.highlight(this.token.text,this.token.lang);if(p!=null&&p!==t
 his.token.text){this.token.escaped=true;this.token.text=p}}if(!this.token.escaped){this.token.text=i(this.token.text,true)}return\"<pre><code\"+(this.token.lang?' class=\"'+this.options.langPrefix+this.token.lang+'\"':\"\")+\">\"+this.token.text+\"</code></pre>\\n\";case\"table\":var l=\"\",q,n,r,k,m;l+=\"<thead>\\n<tr>\\n\";for(n=0;n<this.token.header.length;n++){q=this.inline.output(this.token.header[n]);l+=\"<th\";if(this.token.align[n]){l+=' style=\"text-align:'+this.token.align[n]+'\"'}l+=\">\"+q+\"</th>\\n\"}l+=\"</tr>\\n</thead>\\n\";l+=\"<tbody>\\n\";for(n=0;n<this.token.cells.length;n++){r=this.token.cells[n];l+=\"<tr>\\n\";for(m=0;m<r.length;m++){k=this.inline.output(r[m]);l+=\"<td\";if(this.token.align[m]){l+=' style=\"text-align:'+this.token.align[m]+'\"'}l+=\">\"+k+\"</td>\\n\"}l+=\"</tr>\\n\"}l+=\"</tbody>\\n\";return\"<table>\\n\"+l+\"</table>\\n\";case\"blockquote_start\":var l=\"\";while(this.next().type!==\"blockquote_end\"){l+=this.tok()}return\"<blockquote>\\n\"+
 l+\"</blockquote>\\n\";case\"list_start\":var o=this.token.ordered?\"ol\":\"ul\",l=\"\";while(this.next().type!==\"list_end\"){l+=this.tok()}return\"<\"+o+\">\\n\"+l+\"</\"+o+\">\\n\";case\"list_item_start\":var l=\"\";while(this.next().type!==\"list_item_end\"){l+=this.token.type===\"text\"?this.parseText():this.tok()}return\"<li>\"+l+\"</li>\\n\";case\"loose_item_start\":var l=\"\";while(this.next().type!==\"list_item_end\"){l+=this.tok()}return\"<li>\"+l+\"</li>\\n\";case\"html\":return !this.token.pre&&!this.options.pedantic?this.inline.output(this.token.text):this.token.text;case\"paragraph\":return\"<p>\"+this.inline.output(this.token.text)+\"</p>\\n\";case\"text\":return\"<p>\"+this.parseText()+\"</p>\\n\"}};function i(k,l){return k.replace(!l?/&(?!#?\\w+;)/g:/&/g,\"&amp;\").replace(/</g,\"&lt;\").replace(/>/g,\"&gt;\").replace(/\"/g,\"&quot;\").replace(/'/g,\"&#39;\")}function c(m,l){m=m.source;l=l||\"\";return function k(n,o){if(!n){return new RegExp(m,l)}o=o.source||o;o=o.
 replace(/(^|[^\\[])\\^/g,\"$1\");m=m.replace(n,o);return k}}function j(){}j.exec=j;function g(n){var l=1,m,k;for(;l<arguments.length;l++){m=arguments[l];for(k in m){if(Object.prototype.hasOwnProperty.call(m,k)){n[k]=m[k]}}}return n}function a(k,m,s){if(s||typeof m===\"function\"){if(!s){s=m;m=null}m=g({},a.defaults,m||{});var n=m.highlight,r,l,p=0;try{r=b.lex(k,m)}catch(q){return s(q)}l=r.length;var o=function(){var t,u;try{t=e.parse(r,m)}catch(v){u=v}m.highlight=n;return u?s(u):s(null,t)};if(!n||n.length<3){return o()}delete m.highlight;if(!l){return o()}for(;p<r.length;p++){(function(t){if(t.type!==\"code\"){return --l||o()}return n(t.text,t.lang,function(v,u){if(u==null||u===t.text){return --l||o()}t.text=u;t.escaped=true;--l||o()})})(r[p])}return}try{if(m){m=g({},a.defaults,m)}return e.parse(b.lex(k,m),m)}catch(q){q.message+=\"\\nPlease report this to https://github.com/chjj/marked.\";if((m||a.defaults).silent){return\"<p>An error occured:</p><pre>\"+i(q.message+\"\",true)+\"</p
 re>\"}throw q}}a.options=a.setOptions=function(k){g(a.defaults,k);return a};a.defaults={gfm:true,tables:true,breaks:false,pedantic:false,sanitize:false,smartLists:false,silent:false,highlight:null,langPrefix:\"lang-\",smartypants:false};a.Parser=e;a.parser=e.parse;a.Lexer=b;a.lexer=b.lex;a.InlineLexer=h;a.inlineLexer=h.output;a.parse=a;if(typeof exports===\"object\"){module.exports=a}else{if(typeof define===\"function\"&&define.amd){define(function(){return a})}else{this.marked=a}}}).call(function(){return this||(typeof window!==\"undefined\"?window:global)}());"
+        "  (function(){var d={newline:/^\\n+/,code:/^( {4}[^\\n]+\\n*)+/,fences:j,hr:/^( *[-*_]){3,} *(?:\\n+|$)/,heading:/^ *(#{1,6}) *([^\\n]+?) *#* *(?:\\n+|$)/,nptable:j,lheading:/^([^\\n]+)\\n *(=|-){2,} *(?:\\n+|$)/,blockquote:/^( *>[^\\n]+(\\n[^\\n]+)*\\n*)+/,list:/^( *)(bull) [\\s\\S]+?(?:hr|\\n{2,}(?! )(?!\\1bull )\\n*|\\s*$)/,html:/^ *(?:comment|closed|closing) *(?:\\n{2,}|\\s*$)/,def:/^ *\\[([^\\]]+)\\]: *<?([^\\s>]+)>?(?: +[\"(]([^\\n]+)[\")])? *(?:\\n+|$)/,table:j,paragraph:/^((?:[^\\n]+\\n?(?!hr|heading|lheading|blockquote|tag|def))+)\\n*/,text:/^[^\\n]+/};d.bullet=/(?:[*+-]|\\d+\\.)/;d.item=/^( *)(bull) [^\\n]*(?:\\n(?!\\1bull )[^\\n]*)*/;d.item=c(d.item,\"gm\")(/bull/g,d.bullet)();d.list=c(d.list)(/bull/g,d.bullet)(\"hr\",/\\n+(?=(?: *[-*_]){3,} *(?:\\n+|$))/)();d._tag=\"(?!(?:a|em|strong|small|s|cite|q|dfn|abbr|data|time|code|var|samp|kbd|sub|sup|i|b|u|mark|ruby|rt|rp|bdi|bdo|span|br|wbr|ins|del|img)\\\\b)\\\\w+(?!:/|@)\\\\b\";d.html=c(d.html)(\"comment\",/<!--[\\s\
 \S]*?-->/)(\"closed\",/<(tag)[\\s\\S]+?<\\/\\1>/)(\"closing\",/<tag(?:\"[^\"]*\"|'[^']*'|[^'\">])*?>/)(/tag/g,d._tag)();d.paragraph=c(d.paragraph)(\"hr\",d.hr)(\"heading\",d.heading)(\"lheading\",d.lheading)(\"blockquote\",d.blockquote)(\"tag\",\"<\"+d._tag)(\"def\",d.def)();d.normal=g({},d);d.gfm=g({},d.normal,{fences:/^ *(`{3,}|~{3,}) *(\\S+)? *\\n([\\s\\S]+?)\\s*\\1 *(?:\\n+|$)/,paragraph:/^/});d.gfm.paragraph=c(d.paragraph)(\"(?!\",\"(?!\"+d.gfm.fences.source.replace(\"\\\\1\",\"\\\\2\")+\"|\"+d.list.source.replace(\"\\\\1\",\"\\\\3\")+\"|\")();d.tables=g({},d.gfm,{nptable:/^ *(\\S.*\\|.*)\\n *([-:]+ *\\|[-| :]*)\\n((?:.*\\|.*(?:\\n|$))*)\\n*/,table:/^ *\\|(.+)\\n *\\|( *[-:]+[-| :]*)\\n((?: *\\|.*(?:\\n|$))*)\\n*/});function b(k){this.tokens=[];this.tokens.links={};this.options=k||a.defaults;this.rules=d.normal;if(this.options.gfm){if(this.options.tables){this.rules=d.tables}else{this.rules=d.gfm}}}b.rules=d;b.lex=function(m,k){var l=new b(k);return l.lex(m)};b.prototype.lex=fu
 nction(k){k=k.replace(/\\r\\n|\\r/g,\"\\n\").replace(/\\t/g,\"    \").replace(/\\u00a0/g,\" \").replace(/\\u2424/g,\"\\n\");return this.token(k,true)};b.prototype.token=function(m,s){var m=m.replace(/^ +$/gm,\"\"),q,o,u,r,t,v,k,p,n;while(m){if(u=this.rules.newline.exec(m)){m=m.substring(u[0].length);if(u[0].length>1){this.tokens.push({type:\"space\"})}}if(u=this.rules.code.exec(m)){m=m.substring(u[0].length);u=u[0].replace(/^ {4}/gm,\"\");this.tokens.push({type:\"code\",text:!this.options.pedantic?u.replace(/\\n+$/,\"\"):u});continue}if(u=this.rules.fences.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"code\",lang:u[2],text:u[3]});continue}if(u=this.rules.heading.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"heading\",depth:u[1].length,text:u[2]});continue}if(s&&(u=this.rules.nptable.exec(m))){m=m.substring(u[0].length);v={type:\"table\",header:u[1].replace(/^ *| *\\| *$/g,\"\").split(/ *\\| */),align:u[2].replace(/^ *|\\| *$/g,\"\").split(/ *\\| */),cel
 ls:u[3].replace(/\\n$/,\"\").split(\"\\n\")};for(p=0;p<v.align.length;p++){if(/^ *-+: *$/.test(v.align[p])){v.align[p]=\"right\"}else{if(/^ *:-+: *$/.test(v.align[p])){v.align[p]=\"center\"}else{if(/^ *:-+ *$/.test(v.align[p])){v.align[p]=\"left\"}else{v.align[p]=null}}}}for(p=0;p<v.cells.length;p++){v.cells[p]=v.cells[p].split(/ *\\| */)}this.tokens.push(v);continue}if(u=this.rules.lheading.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"heading\",depth:u[2]===\"=\"?1:2,text:u[1]});continue}if(u=this.rules.hr.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"hr\"});continue}if(u=this.rules.blockquote.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"blockquote_start\"});u=u[0].replace(/^ *> ?/gm,\"\");this.token(u,s);this.tokens.push({type:\"blockquote_end\"});continue}if(u=this.rules.list.exec(m)){m=m.substring(u[0].length);r=u[2];this.tokens.push({type:\"list_start\",ordered:r.length>1});u=u[0].match(this.rules.item);q=false;n=u.length;p=0;for(;
 p<n;p++){v=u[p];k=v.length;v=v.replace(/^ *([*+-]|\\d+\\.) +/,\"\");if(~v.indexOf(\"\\n \")){k-=v.length;v=!this.options.pedantic?v.replace(new RegExp(\"^ {1,\"+k+\"}\",\"gm\"),\"\"):v.replace(/^ {1,4}/gm,\"\")}if(this.options.smartLists&&p!==n-1){t=d.bullet.exec(u[p+1])[0];if(r!==t&&!(r.length>1&&t.length>1)){m=u.slice(p+1).join(\"\\n\")+m;p=n-1}}o=q||/\\n\\n(?!\\s*$)/.test(v);if(p!==n-1){q=v.charAt(v.length-1)===\"\\n\";if(!o){o=q}}this.tokens.push({type:o?\"loose_item_start\":\"list_item_start\"});this.token(v,false);this.tokens.push({type:\"list_item_end\"})}this.tokens.push({type:\"list_end\"});continue}if(u=this.rules.html.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:this.options.sanitize?\"paragraph\":\"html\",pre:u[1]===\"pre\"||u[1]===\"script\"||u[1]===\"style\",text:u[0]});continue}if(s&&(u=this.rules.def.exec(m))){m=m.substring(u[0].length);this.tokens.links[u[1].toLowerCase()]={href:u[2],title:u[3]};continue}if(s&&(u=this.rules.table.exec(m))){m=m.substrin
 g(u[0].length);v={type:\"table\",header:u[1].replace(/^ *| *\\| *$/g,\"\").split(/ *\\| */),align:u[2].replace(/^ *|\\| *$/g,\"\").split(/ *\\| */),cells:u[3].replace(/(?: *\\| *)?\\n$/,\"\").split(\"\\n\")};for(p=0;p<v.align.length;p++){if(/^ *-+: *$/.test(v.align[p])){v.align[p]=\"right\"}else{if(/^ *:-+: *$/.test(v.align[p])){v.align[p]=\"center\"}else{if(/^ *:-+ *$/.test(v.align[p])){v.align[p]=\"left\"}else{v.align[p]=null}}}}for(p=0;p<v.cells.length;p++){v.cells[p]=v.cells[p].replace(/^ *\\| *| *\\| *$/g,\"\").split(/ *\\| */)}this.tokens.push(v);continue}if(s&&(u=this.rules.paragraph.exec(m))){m=m.substring(u[0].length);this.tokens.push({type:\"paragraph\",text:u[1].charAt(u[1].length-1)===\"\\n\"?u[1].slice(0,-1):u[1]});continue}if(u=this.rules.text.exec(m)){m=m.substring(u[0].length);this.tokens.push({type:\"text\",text:u[0]});continue}if(m){throw new Error(\"Infinite loop on byte: \"+m.charCodeAt(0))}}return this.tokens};var f={escape:/^\\\\([\\\\`*{}\\[\\]()#+\\-.!_>])/,a
 utolink:/^<([^ >]+(@|:\\/)[^ >]+)>/,url:j,tag:/^<!--[\\s\\S]*?-->|^<\\/?\\w+(?:\"[^\"]*\"|'[^']*'|[^'\">])*?>/,link:/^!?\\[(inside)\\]\\(href\\)/,reflink:/^!?\\[(inside)\\]\\s*\\[([^\\]]*)\\]/,nolink:/^!?\\[((?:\\[[^\\]]*\\]|[^\\[\\]])*)\\]/,strong:/^__([\\s\\S]+?)__(?!_)|^\\*\\*([\\s\\S]+?)\\*\\*(?!\\*)/,em:/^\\b_((?:__|[\\s\\S])+?)_\\b|^\\*((?:\\*\\*|[\\s\\S])+?)\\*(?!\\*)/,code:/^(`+)\\s*([\\s\\S]*?[^`])\\s*\\1(?!`)/,br:/^ {2,}\\n(?!\\s*$)/,del:j,text:/^[\\s\\S]+?(?=[\\\\<!\\[_*`]| {2,}\\n|$)/};f._inside=/(?:\\[[^\\]]*\\]|[^\\[\\]]|\\](?=[^\\[]*\\]))*/;f._href=/\\s*<?([\\s\\S]*?)>?(?:\\s+['\"]([\\s\\S]*?)['\"])?\\s*/;f.link=c(f.link)(\"inside\",f._inside)(\"href\",f._href)();f.reflink=c(f.reflink)(\"inside\",f._inside)();f.normal=g({},f);f.pedantic=g({},f.normal,{strong:/^__(?=\\S)([\\s\\S]*?\\S)__(?!_)|^\\*\\*(?=\\S)([\\s\\S]*?\\S)\\*\\*(?!\\*)/,em:/^_(?=\\S)([\\s\\S]*?\\S)_(?!_)|^\\*(?=\\S)([\\s\\S]*?\\S)\\*(?!\\*)/});f.gfm=g({},f.normal,{escape:c(f.escape)(\"])\",\"~|])\")(),u
 rl:/^(https?:\\/\\/[^\\s<]+[^<.,:;\"')\\]\\s])/,del:/^~~(?=\\S)([\\s\\S]*?\\S)~~/,text:c(f.text)(\"]|\",\"~]|\")(\"|\",\"|https?://|\")()});f.breaks=g({},f.gfm,{br:c(f.br)(\"{2,}\",\"*\")(),text:c(f.gfm.text)(\"{2,}\",\"*\")()});function h(k,l){this.options=l||a.defaults;this.links=k;this.rules=f.normal;if(!this.links){throw new Error(\"Tokens array requires a `links` property.\")}if(this.options.gfm){if(this.options.breaks){this.rules=f.breaks}else{this.rules=f.gfm}}else{if(this.options.pedantic){this.rules=f.pedantic}}}h.rules=f;h.output=function(n,k,l){var m=new h(k,l);return m.output(n)};h.prototype.output=function(p){var l=\"\",n,o,k,m;while(p){if(m=this.rules.escape.exec(p)){p=p.substring(m[0].length);l+=m[1];continue}if(m=this.rules.autolink.exec(p)){p=p.substring(m[0].length);if(m[2]===\"@\"){o=m[1].charAt(6)===\":\"?this.mangle(m[1].substring(7)):this.mangle(m[1]);k=this.mangle(\"mailto:\")+o}else{o=i(m[1]);k=o}l+='<a href=\"'+k+'\">'+o+\"</a>\";continue}if(m=this.rules.url
 .exec(p)){p=p.substring(m[0].length);o=i(m[1]);k=o;l+='<a href=\"'+k+'\">'+o+\"</a>\";continue}if(m=this.rules.tag.exec(p)){p=p.substring(m[0].length);l+=this.options.sanitize?i(m[0]):m[0];continue}if(m=this.rules.link.exec(p)){p=p.substring(m[0].length);l+=this.outputLink(m,{href:m[2],title:m[3]});continue}if((m=this.rules.reflink.exec(p))||(m=this.rules.nolink.exec(p))){p=p.substring(m[0].length);n=(m[2]||m[1]).replace(/\\s+/g,\" \");n=this.links[n.toLowerCase()];if(!n||!n.href){l+=m[0].charAt(0);p=m[0].substring(1)+p;continue}l+=this.outputLink(m,n);continue}if(m=this.rules.strong.exec(p)){p=p.substring(m[0].length);l+=\"<strong>\"+this.output(m[2]||m[1])+\"</strong>\";continue}if(m=this.rules.em.exec(p)){p=p.substring(m[0].length);l+=\"<em>\"+this.output(m[2]||m[1])+\"</em>\";continue}if(m=this.rules.code.exec(p)){p=p.substring(m[0].length);l+=\"<code>\"+i(m[2],true)+\"</code>\";continue}if(m=this.rules.br.exec(p)){p=p.substring(m[0].length);l+=\"<br>\";continue}if(m=this.rules.
 del.exec(p)){p=p.substring(m[0].length);l+=\"<del>\"+this.output(m[1])+\"</del>\";continue}if(m=this.rules.text.exec(p)){p=p.substring(m[0].length);l+=i(this.smartypants(m[0]));continue}if(p){throw new Error(\"Infinite loop on byte: \"+p.charCodeAt(0))}}return l};h.prototype.outputLink=function(k,l){if(k[0].charAt(0)!==\"!\"){return'<a href=\"'+i(l.href)+'\"'+(l.title?' title=\"'+i(l.title)+'\"':\"\")+\">\"+this.output(k[1])+\"</a>\"}else{return'<img src=\"'+i(l.href)+'\" alt=\"'+i(k[1])+'\"'+(l.title?' title=\"'+i(l.title)+'\"':\"\")+\">\"}};h.prototype.smartypants=function(k){if(!this.options.smartypants){return k}return k.replace(/--/g,\"\\u2014\").replace(/(^|[-\\u2014/(\\[{\"\\s])'/g,\"$1\\u2018\").replace(/'/g,\"\\u2019\").replace(/(^|[-\\u2014/(\\[{\\u2018\\s])\"/g,\"$1\\u201c\").replace(/\"/g,\"\\u201d\").replace(/\\.{3}/g,\"\\u2026\")};h.prototype.mangle=function(p){var m=\"\",k=p.length,n=0,o;for(;n<k;n++){o=p.charCodeAt(n);if(Math.random()>0.5){o=\"x\"+o.toString(16)}m+=\
 "&#\"+o+\";\"}return m};function e(k){this.tokens=[];this.token=null;this.options=k||a.defaults}e.parse=function(l,k){var m=new e(k);return m.parse(l)};e.prototype.parse=function(l){this.inline=new h(l.links,this.options);this.tokens=l.reverse();var k=\"\";while(this.next()){k+=this.tok()}return k};e.prototype.next=function(){return this.token=this.tokens.pop()};e.prototype.peek=function(){return this.tokens[this.tokens.length-1]||0};e.prototype.parseText=function(){var k=this.token.text;while(this.peek().type===\"text\"){k+=\"\\n\"+this.next().text}return this.inline.output(k)};e.prototype.tok=function(){switch(this.token.type){case\"space\":return\"\";case\"hr\":return\"<hr>\\n\";case\"heading\":return\"<h\"+this.token.depth+' id=\"'+this.token.text.toLowerCase().replace(/[^\\w]+/g,\"-\")+'\">'+this.inline.output(this.token.text)+\"</h\"+this.token.depth+\">\\n\";case\"code\":if(this.options.highlight){var p=this.options.highlight(this.token.text,this.token.lang);if(p!=null&&p!==t
 his.token.text){this.token.escaped=true;this.token.text=p}}if(!this.token.escaped){this.token.text=i(this.token.text,true)}return\"<pre><code\"+(this.token.lang?' class=\"'+this.options.langPrefix+this.token.lang+'\"':\"\")+\">\"+this.token.text+\"</code></pre>\\n\";case\"table\":var l=\"\",q,n,r,k,m;l+=\"<thead>\\n<tr>\\n\";for(n=0;n<this.token.header.length;n++){q=this.inline.output(this.token.header[n]);l+=\"<th\";if(this.token.align[n]){l+=' style=\"text-align:'+this.token.align[n]+'\"'}l+=\">\"+q+\"</th>\\n\"}l+=\"</tr>\\n</thead>\\n\";l+=\"<tbody>\\n\";for(n=0;n<this.token.cells.length;n++){r=this.token.cells[n];l+=\"<tr>\\n\";for(m=0;m<r.length;m++){k=this.inline.output(r[m]);l+=\"<td\";if(this.token.align[m]){l+=' style=\"text-align:'+this.token.align[m]+'\"'}l+=\">\"+k+\"</td>\\n\"}l+=\"</tr>\\n\"}l+=\"</tbody>\\n\";return\"<table>\\n\"+l+\"</table>\\n\";case\"blockquote_start\":var l=\"\";while(this.next().type!==\"blockquote_end\"){l+=this.tok()}return\"<blockquote>\\n\"+
 l+\"</blockquote>\\n\";case\"list_start\":var o=this.token.ordered?\"ol\":\"ul\",l=\"\";while(this.next().type!==\"list_end\"){l+=this.tok()}return\"<\"+o+\">\\n\"+l+\"</\"+o+\">\\n\";case\"list_item_start\":var l=\"\";while(this.next().type!==\"list_item_end\"){l+=this.token.type===\"text\"?this.parseText():this.tok()}return\"<li>\"+l+\"</li>\\n\";case\"loose_item_start\":var l=\"\";while(this.next().type!==\"list_item_end\"){l+=this.tok()}return\"<li>\"+l+\"</li>\\n\";case\"html\":return !this.token.pre&&!this.options.pedantic?this.inline.output(this.token.text):this.token.text;case\"paragraph\":return\"<p>\"+this.inline.output(this.token.text)+\"</p>\\n\";case\"text\":return\"<p>\"+this.parseText()+\"</p>\\n\"}};function i(k,l){return k.replace(!l?/&(?!#?\\w+;)/g:/&/g,\"&amp;\").replace(/</g,\"&lt;\").replace(/>/g,\"&gt;\").replace(/\"/g,\"&quot;\").replace(/'/g,\"&#39;\")}function c(m,l){m=m.source;l=l||\"\";return function k(n,o){if(!n){return new RegExp(m,l)}o=o.source||o;o=o.
 replace(/(^|[^\\[])\\^/g,\"$1\");m=m.replace(n,o);return k}}function j(){}j.exec=j;function g(n){var l=1,m,k;for(;l<arguments.length;l++){m=arguments[l];for(k in m){if(Object.prototype.hasOwnProperty.call(m,k)){n[k]=m[k]}}}return n}function a(k,m,s){if(s||typeof m===\"function\"){if(!s){s=m;m=null}m=g({},a.defaults,m||{});var n=m.highlight,r,l,p=0;try{r=b.lex(k,m)}catch(q){return s(q)}l=r.length;var o=function(){var t,u;try{t=e.parse(r,m)}catch(v){u=v}m.highlight=n;return u?s(u):s(null,t)};if(!n||n.length<3){return o()}delete m.highlight;if(!l){return o()}for(;p<r.length;p++){(function(t){if(t.type!==\"code\"){return --l||o()}return n(t.text,t.lang,function(v,u){if(u==null||u===t.text){return --l||o()}t.text=u;t.escaped=true;--l||o()})})(r[p])}return}try{if(m){m=g({},a.defaults,m)}return e.parse(b.lex(k,m),m)}catch(q){q.message+=\"\\nPlease report this to https://github.com/chjj/marked.\";if((m||a.defaults).silent){return\"<p>An error occured:</p><pre>\"+i(q.message+\"\",true)+\"</p
 re>\"}throw q}}a.options=a.setOptions=function(k){g(a.defaults,k);return a};a.defaults={gfm:true,tables:true,breaks:false,pedantic:false,sanitize:false,smartLists:false,silent:false,highlight:null,langPrefix:\"lang-\",smartypants:false};a.Parser=e;a.parser=e.parse;a.Lexer=b;a.lexer=b.lex;a.InlineLexer=h;a.inlineLexer=h.output;a.parse=a;if(typeof exports===\"object\"){module.exports=a}else{if(typeof define===\"function\"&&define.amd){define(function(){return a})}else{this.marked=a}}}).call(function(){return this||(typeof window!==\"undefined\"?window:global)}());" // NOLINT(whitespace/line_length)
         "  function loaded() {"
         "    marked.setOptions({ breaks: true });"
         "    document.body.innerHTML = marked(" + markdown + ");"

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/include/process/logging.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/logging.hpp b/3rdparty/libprocess/include/process/logging.hpp
index 0882266..1220223 100644
--- a/3rdparty/libprocess/include/process/logging.hpp
+++ b/3rdparty/libprocess/include/process/logging.hpp
@@ -62,9 +62,11 @@ private:
     }
 
     if (v.get() < 0) {
-      return http::BadRequest("Invalid level '" + stringify(v.get()) + "'.\n");
+      return http::BadRequest(
+          "Invalid level '" + stringify(v.get()) + "'.\n");
     } else if (v.get() < original) {
-      return http::BadRequest("'" + stringify(v.get()) + "' < original level.\n");
+      return http::BadRequest(
+          "'" + stringify(v.get()) + "' < original level.\n");
     }
 
     Try<Duration> d = Duration::parse(duration.get());

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/src/decoder.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/decoder.hpp b/3rdparty/libprocess/src/decoder.hpp
index 44f7cd4..c329882 100644
--- a/3rdparty/libprocess/src/decoder.hpp
+++ b/3rdparty/libprocess/src/decoder.hpp
@@ -105,8 +105,11 @@ private:
     decoder->field.clear();
     decoder->value.clear();
 
-    decoder->request->method = http_method_str((http_method) decoder->parser.method);
+    decoder->request->method =
+      http_method_str((http_method) decoder->parser.method);
+
     decoder->request->keepAlive = http_should_keep_alive(&decoder->parser);
+
     return 0;
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/src/gate.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/gate.hpp b/3rdparty/libprocess/src/gate.hpp
index 200fce2..78f944c 100644
--- a/3rdparty/libprocess/src/gate.hpp
+++ b/3rdparty/libprocess/src/gate.hpp
@@ -1,9 +1,7 @@
-#ifndef GATE_H
-#define GATE_H
+#ifndef __GATE_HPP__
+#define __GATE_HPP__
 
-/* TODO(benh): Provide an implementation directly on-top-of futex's for Linux. */
-//#ifdef __linux__
-//#else
+// TODO(benh): Build implementation directly on-top-of futex's for Linux.
 
 class Gate
 {
@@ -99,6 +97,4 @@ public:
   }
 };
 
-//#endif
-
-#endif /* GATE_H */
+#endif // __GATE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/src/process.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/process.cpp b/3rdparty/libprocess/src/process.cpp
index 27ca5bb..da2d4ac 100644
--- a/3rdparty/libprocess/src/process.cpp
+++ b/3rdparty/libprocess/src/process.cpp
@@ -878,7 +878,8 @@ void handle_async(struct ev_loop* loop, ev_async* _, int revents)
     if (update_timer) {
       if (!timeouts->empty()) {
         // Determine when the next timer should fire.
-        timeouts_watcher.repeat = (timeouts->begin()->first - Clock::now()).secs();
+        timeouts_watcher.repeat =
+          (timeouts->begin()->first - Clock::now()).secs();
 
         if (timeouts_watcher.repeat <= 0) {
           // Feed the event now!
@@ -3167,7 +3168,11 @@ void ProcessBase::enqueue(Event* event, bool inject)
 }
 
 
-void ProcessBase::inject(const UPID& from, const string& name, const char* data, size_t length)
+void ProcessBase::inject(
+    const UPID& from,
+    const string& name,
+    const char* data,
+    size_t length)
 {
   if (!from)
     return;
@@ -3178,7 +3183,11 @@ void ProcessBase::inject(const UPID& from, const string& name, const char* data,
 }
 
 
-void ProcessBase::send(const UPID& to, const string& name, const char* data, size_t length)
+void ProcessBase::send(
+    const UPID& to,
+    const string& name,
+    const char* data,
+    size_t length)
 {
   if (!to) {
     return;
@@ -3909,7 +3918,8 @@ void _splice(
                    WeakFuture<size_t>(read)));
 
   read
-    .onReady(lambda::bind(&__splice, from, to, chunk, data, promise, lambda::_1))
+    .onReady(
+        lambda::bind(&__splice, from, to, chunk, data, promise, lambda::_1))
     .onFailed(lambda::bind(&___splice, promise, lambda::_1))
     .onDiscarded(lambda::bind(&____splice, promise));
 }

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/src/synchronized.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/synchronized.hpp b/3rdparty/libprocess/src/synchronized.hpp
index 0804e5b..577a5fc 100644
--- a/3rdparty/libprocess/src/synchronized.hpp
+++ b/3rdparty/libprocess/src/synchronized.hpp
@@ -99,6 +99,11 @@ private:
   (__synchronizable_ ## s)
 
 
-#define SYNCHRONIZED_INITIALIZER Synchronizable(PTHREAD_MUTEX_NORMAL)
-#define SYNCHRONIZED_INITIALIZER_DEBUG Synchronizable(PTHREAD_MUTEX_ERRORCHECK)
-#define SYNCHRONIZED_INITIALIZER_RECURSIVE Synchronizable(PTHREAD_MUTEX_RECURSIVE)
+#define SYNCHRONIZED_INITIALIZER                \
+  Synchronizable(PTHREAD_MUTEX_NORMAL)
+
+#define SYNCHRONIZED_INITIALIZER_DEBUG          \
+  Synchronizable(PTHREAD_MUTEX_ERRORCHECK)
+
+#define SYNCHRONIZED_INITIALIZER_RECURSIVE      \
+  Synchronizable(PTHREAD_MUTEX_RECURSIVE)

http://git-wip-us.apache.org/repos/asf/mesos/blob/33b1a6a1/3rdparty/libprocess/src/tests/http_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/tests/http_tests.cpp b/3rdparty/libprocess/src/tests/http_tests.cpp
index 06ce178..f58a129 100644
--- a/3rdparty/libprocess/src/tests/http_tests.cpp
+++ b/3rdparty/libprocess/src/tests/http_tests.cpp
@@ -276,8 +276,12 @@ TEST(HTTP, Post)
   EXPECT_CALL(process, post(_))
     .WillOnce(Invoke(validatePost));
 
-  future =
-    http::post(process.self(), "post", None(), "This is the payload.", "text/plain");
+  future = http::post(
+      process.self(),
+      "post",
+      None(),
+      "This is the payload.",
+      "text/plain");
 
   AWAIT_READY(future);
   ASSERT_EQ(http::statuses[200], future.get().status);