You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mesos.apache.org by an...@apache.org on 2016/10/02 16:29:36 UTC

[1/3] mesos git commit: Fixed usage of "can not" vs. "cannot".

Repository: mesos
Updated Branches:
  refs/heads/master 37a75f755 -> 2e013890e


Fixed usage of "can not" vs. "cannot".

For style reasons, the latter should usually be preferred to the former.

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


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

Branch: refs/heads/master
Commit: d4492f3ed9367292207205196c7d715e6f38650f
Parents: 37a75f7
Author: Neil Conway <ne...@gmail.com>
Authored: Sun Oct 2 08:58:48 2016 -0700
Committer: Anand Mazumdar <an...@apache.org>
Committed: Sun Oct 2 08:58:48 2016 -0700

----------------------------------------------------------------------
 configure.ac                                                 | 6 +++---
 docs/modules.md                                              | 2 +-
 include/mesos/allocator/allocator.proto                      | 2 +-
 include/mesos/mesos.proto                                    | 2 +-
 include/mesos/state/state.hpp                                | 2 +-
 include/mesos/v1/allocator/allocator.proto                   | 2 +-
 include/mesos/v1/mesos.proto                                 | 2 +-
 src/cli/mesos.cpp                                            | 2 +-
 src/common/resources_utils.cpp                               | 2 +-
 src/docker/docker.cpp                                        | 2 +-
 src/java/src/org/apache/mesos/state/State.java               | 2 +-
 src/java/src/org/apache/mesos/state/ZooKeeperState.java      | 2 +-
 src/master/allocator/mesos/hierarchical.cpp                  | 2 +-
 src/master/master.hpp                                        | 8 ++++----
 src/master/quota_handler.cpp                                 | 2 +-
 src/slave/containerizer/mesos/isolators/gpu/allocator.cpp    | 2 +-
 .../containerizer/mesos/isolators/network/port_mapping.cpp   | 2 +-
 src/state/leveldb.cpp                                        | 4 ++--
 src/tests/master_authorization_tests.cpp                     | 2 +-
 src/tests/slave_authorization_tests.cpp                      | 2 +-
 20 files changed, 26 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/configure.ac
----------------------------------------------------------------------
diff --git a/configure.ac b/configure.ac
index 57482d3..8f971c9 100644
--- a/configure.ac
+++ b/configure.ac
@@ -949,7 +949,7 @@ if test "x$enable_java" = "xyes"; then
     AC_PATH_PROG([JAVA], [java], [$JAVA])
 
     if test "x$JAVA" = "x" || test "x$JAVAC" = "x"; then
-      AC_MSG_ERROR([can not guess JAVA_HOME (no 'java' or 'javac' found)])
+      AC_MSG_ERROR([cannot guess JAVA_HOME (no 'java' or 'javac' found)])
     fi
 
     AC_MSG_CHECKING([value of Java system property 'java.home'])
@@ -1082,7 +1082,7 @@ __EOF__
     AC_PATH_PROG([MVN], [mvn], [$MVN])
 
     if test "x$MVN" = "x"; then
-      AC_MSG_ERROR([can not find mvn on your path
+      AC_MSG_ERROR([cannot find mvn on your path
 -------------------------------------------------------------------
 You may want verify that Maven has been correctly installed and
 added to your PATH or set the MAVEN_HOME environment variable
@@ -1094,7 +1094,7 @@ to point to your Maven installation.
     AC_PATH_PROGS([MVN], [mvn], [$MVN], [$MAVEN_HOME/bin])
 
     if test "x$MVN" = "x"; then
-      AC_MSG_ERROR([can not find mvn inside $MAVEN_HOME/bin
+      AC_MSG_ERROR([cannot find mvn inside $MAVEN_HOME/bin
 -------------------------------------------------------------------
 You may want verify the MAVEN_HOME validity or check that Maven
 has been correctly installed.

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/docs/modules.md
----------------------------------------------------------------------
diff --git a/docs/modules.md b/docs/modules.md
index cf29a23..701b01f 100644
--- a/docs/modules.md
+++ b/docs/modules.md
@@ -31,7 +31,7 @@ without having to know all the internal details.
 
 ## Where can Mesos modules be used?
 Modules can be specified for master, agent and tests. Modules can also be used
-with schedulers that link against libmesos. Currently, modules can not be
+with schedulers that link against libmesos. Currently, modules cannot be
 used with executors.
 
 ## <a name="Invoking"></a>Invoking Mesos modules

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/include/mesos/allocator/allocator.proto
----------------------------------------------------------------------
diff --git a/include/mesos/allocator/allocator.proto b/include/mesos/allocator/allocator.proto
index df7e6db..9fc8bac 100644
--- a/include/mesos/allocator/allocator.proto
+++ b/include/mesos/allocator/allocator.proto
@@ -37,7 +37,7 @@ message InverseOfferStatus {
     // violated its SLAs.
     ACCEPT = 2;
     // The framework wants to block the maintenance operation from happening. An
-    // example would be that it can not meet its SLA by losing resources.
+    // example would be that it cannot meet its SLA by losing resources.
     DECLINE = 3;
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/include/mesos/mesos.proto
----------------------------------------------------------------------
diff --git a/include/mesos/mesos.proto b/include/mesos/mesos.proto
index e71a583..2a3c251 100644
--- a/include/mesos/mesos.proto
+++ b/include/mesos/mesos.proto
@@ -848,7 +848,7 @@ message Resource {
       }
 
       // A mounted file-system set up by the Agent administrator. This
-      // can only be used exclusively: a framework can not accept a
+      // can only be used exclusively: a framework cannot accept a
       // partial amount of this disk.
       message Mount {
         // Path to mount point (e.g., /mnt/raid/disk0).

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/include/mesos/state/state.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/state/state.hpp b/include/mesos/state/state.hpp
index 1117253..8f7f3ad 100644
--- a/include/mesos/state/state.hpp
+++ b/include/mesos/state/state.hpp
@@ -43,7 +43,7 @@ namespace state {
 // replicated guarantees.
 //
 // Note that the semantics of 'fetch' and 'store' provide
-// atomicity. That is, you can not store a variable that has changed
+// atomicity. That is, you cannot store a variable that has changed
 // since you did the last fetch. That is, if a store succeeds then no
 // other writes have been performed on the variable since your fetch.
 //

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/include/mesos/v1/allocator/allocator.proto
----------------------------------------------------------------------
diff --git a/include/mesos/v1/allocator/allocator.proto b/include/mesos/v1/allocator/allocator.proto
index a92a1e5..73d45b3 100644
--- a/include/mesos/v1/allocator/allocator.proto
+++ b/include/mesos/v1/allocator/allocator.proto
@@ -37,7 +37,7 @@ message InverseOfferStatus {
     // violated its SLAs.
     ACCEPT = 2;
     // The framework wants to block the maintenance operation from happening. An
-    // example would be that it can not meet its SLA by losing resources.
+    // example would be that it cannot meet its SLA by losing resources.
     DECLINE = 3;
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/include/mesos/v1/mesos.proto
----------------------------------------------------------------------
diff --git a/include/mesos/v1/mesos.proto b/include/mesos/v1/mesos.proto
index e7b8a0f..57846a5 100644
--- a/include/mesos/v1/mesos.proto
+++ b/include/mesos/v1/mesos.proto
@@ -847,7 +847,7 @@ message Resource {
       }
 
       // A mounted file-system set up by the Agent administrator. This
-      // can only be used exclusively: a framework can not accept a
+      // can only be used exclusively: a framework cannot accept a
       // partial amount of this disk.
       message Mount {
         // Path to mount point (e.g., /mnt/raid/disk0).

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/cli/mesos.cpp
----------------------------------------------------------------------
diff --git a/src/cli/mesos.cpp b/src/cli/mesos.cpp
index ac0b5dd..b347f39 100644
--- a/src/cli/mesos.cpp
+++ b/src/cli/mesos.cpp
@@ -130,7 +130,7 @@ int main(int argc, char** argv)
     execvp(executable.c_str(), argv + 1);
     if (errno == ENOENT) {
       cerr << "'" << command << "' is not a valid command "
-           << "(or can not be found)" << endl;
+           << "(or cannot be found)" << endl;
     } else {
       cerr << "Failed to execute '" << command << "': "
            << os::strerror(errno) << endl;

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/common/resources_utils.cpp
----------------------------------------------------------------------
diff --git a/src/common/resources_utils.cpp b/src/common/resources_utils.cpp
index 4657903..c308843 100644
--- a/src/common/resources_utils.cpp
+++ b/src/common/resources_utils.cpp
@@ -30,7 +30,7 @@ bool needCheckpointing(const Resource& resource)
 
 
 // NOTE: We effectively duplicate the logic in 'Resources::apply'
-// which is less than ideal. But we can not simply create
+// which is less than ideal. But we cannot simply create
 // 'Offer::Operation' and invoke 'Resources::apply' here.
 // 'RESERVE' operation requires that the specified resources are
 // dynamically reserved only, and 'CREATE' requires that the

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/docker/docker.cpp
----------------------------------------------------------------------
diff --git a/src/docker/docker.cpp b/src/docker/docker.cpp
index 24a6e14..50fda39 100755
--- a/src/docker/docker.cpp
+++ b/src/docker/docker.cpp
@@ -851,7 +851,7 @@ Future<Nothing> Docker::stop(
 {
   int timeoutSecs = (int) timeout.secs();
   if (timeoutSecs < 0) {
-    return Failure("A negative timeout can not be applied to docker stop: " +
+    return Failure("A negative timeout cannot be applied to docker stop: " +
                    stringify(timeoutSecs));
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/java/src/org/apache/mesos/state/State.java
----------------------------------------------------------------------
diff --git a/src/java/src/org/apache/mesos/state/State.java b/src/java/src/org/apache/mesos/state/State.java
index 58885d9..2054f59 100644
--- a/src/java/src/org/apache/mesos/state/State.java
+++ b/src/java/src/org/apache/mesos/state/State.java
@@ -31,7 +31,7 @@ import java.util.concurrent.Future;
  * replicated guarantees.
  * <p>
  * Note that the semantics of 'fetch' and 'store' provide
- * atomicity. That is, you can not store a variable that has changed
+ * atomicity. That is, you cannot store a variable that has changed
  * since you did the last fetch. That is, if a store succeeds then no
  * other writes have been performed on the variable since your fetch.
  *

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/java/src/org/apache/mesos/state/ZooKeeperState.java
----------------------------------------------------------------------
diff --git a/src/java/src/org/apache/mesos/state/ZooKeeperState.java b/src/java/src/org/apache/mesos/state/ZooKeeperState.java
index cb0eba0..e17f008 100644
--- a/src/java/src/org/apache/mesos/state/ZooKeeperState.java
+++ b/src/java/src/org/apache/mesos/state/ZooKeeperState.java
@@ -23,7 +23,7 @@ import java.util.concurrent.TimeUnit;
 /**
  * Implementation of State that uses ZooKeeper to store
  * variables/values. Note that this means the values associated with
- * variables can not be more than 1 MB (actually slightly less since
+ * variables cannot be more than 1 MB (actually slightly less since
  * we store some bookkeeping information).
  */
 public class ZooKeeperState extends AbstractState {

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/master/allocator/mesos/hierarchical.cpp
----------------------------------------------------------------------
diff --git a/src/master/allocator/mesos/hierarchical.cpp b/src/master/allocator/mesos/hierarchical.cpp
index e6ce5f1..c8f9492 100644
--- a/src/master/allocator/mesos/hierarchical.cpp
+++ b/src/master/allocator/mesos/hierarchical.cpp
@@ -1636,7 +1636,7 @@ void HierarchicalAllocatorProcess::allocate(
           resources = resources.nonRevocable();
         }
 
-        // If the resources are not allocatable, ignore. We can not break
+        // If the resources are not allocatable, ignore. We cannot break
         // here, because another framework under the same role could accept
         // revocable resources and breaking would skip all other frameworks.
         if (!allocatable(resources)) {

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/master/master.hpp
----------------------------------------------------------------------
diff --git a/src/master/master.hpp b/src/master/master.hpp
index 48011ea..6d2b4f5 100644
--- a/src/master/master.hpp
+++ b/src/master/master.hpp
@@ -2393,7 +2393,7 @@ struct Framework
     // MESOS-703.
 
     if (source.user() != info.user()) {
-      LOG(WARNING) << "Can not update FrameworkInfo.user to '" << info.user()
+      LOG(WARNING) << "Cannot update FrameworkInfo.user to '" << info.user()
                    << "' for framework " << id() << ". Check MESOS-703";
     }
 
@@ -2406,13 +2406,13 @@ struct Framework
     }
 
     if (source.checkpoint() != info.checkpoint()) {
-      LOG(WARNING) << "Can not update FrameworkInfo.checkpoint to '"
+      LOG(WARNING) << "Cannot update FrameworkInfo.checkpoint to '"
                    << stringify(info.checkpoint()) << "' for framework " << id()
                    << ". Check MESOS-703";
     }
 
     if (source.role() != info.role()) {
-      LOG(WARNING) << "Can not update FrameworkInfo.role to '" << info.role()
+      LOG(WARNING) << "Cannot update FrameworkInfo.role to '" << info.role()
                    << "' for framework " << id() << ". Check MESOS-703";
     }
 
@@ -2423,7 +2423,7 @@ struct Framework
     }
 
     if (source.principal() != info.principal()) {
-      LOG(WARNING) << "Can not update FrameworkInfo.principal to '"
+      LOG(WARNING) << "Cannot update FrameworkInfo.principal to '"
                    << info.principal() << "' for framework " << id()
                    << ". Check MESOS-703";
     }

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/master/quota_handler.cpp
----------------------------------------------------------------------
diff --git a/src/master/quota_handler.cpp b/src/master/quota_handler.cpp
index bf6a613..d87d6c6 100644
--- a/src/master/quota_handler.cpp
+++ b/src/master/quota_handler.cpp
@@ -362,7 +362,7 @@ Future<http::Response> Master::QuotaHandler::_set(
   // TODO(joerg84): Update error message once quota update is in place.
   if (master->quotas.contains(quotaInfo.role())) {
     return BadRequest(
-        "Failed to validate set quota request: Can not set quota"
+        "Failed to validate set quota request: Cannot set quota"
         " for role '" + quotaInfo.role() + "' which already has quota");
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/slave/containerizer/mesos/isolators/gpu/allocator.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/isolators/gpu/allocator.cpp b/src/slave/containerizer/mesos/isolators/gpu/allocator.cpp
index c1a87e9..2e72269 100644
--- a/src/slave/containerizer/mesos/isolators/gpu/allocator.cpp
+++ b/src/slave/containerizer/mesos/isolators/gpu/allocator.cpp
@@ -201,7 +201,7 @@ static Try<Resources> enumerateGpuResources(const Flags& flags)
   }
 
   if (resources.gpus().isSome() && !flags.nvidia_gpu_devices.isSome()) {
-    return Error("The `gpus` resource can not be set without also"
+    return Error("The `gpus` resource cannot be set without also"
                  " setting `--nvidia_gpu_devices`");
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/slave/containerizer/mesos/isolators/network/port_mapping.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/isolators/network/port_mapping.cpp b/src/slave/containerizer/mesos/isolators/network/port_mapping.cpp
index 01355a1..20fb6ab 100644
--- a/src/slave/containerizer/mesos/isolators/network/port_mapping.cpp
+++ b/src/slave/containerizer/mesos/isolators/network/port_mapping.cpp
@@ -2600,7 +2600,7 @@ Future<Nothing> PortMappingIsolatorProcess::isolate(
         createVethPair.error());
   }
 
-  // We can not reuse the existing veth pair, because one of them is
+  // We cannot reuse the existing veth pair, because one of them is
   // still inside another container.
   if (!createVethPair.get()) {
     return Failure(

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/state/leveldb.cpp
----------------------------------------------------------------------
diff --git a/src/state/leveldb.cpp b/src/state/leveldb.cpp
index 5719265..9ced03a 100644
--- a/src/state/leveldb.cpp
+++ b/src/state/leveldb.cpp
@@ -169,7 +169,7 @@ Future<bool> LevelDBStorageProcess::set(const Entry& entry, const UUID& uuid)
 
   // Note that the read (i.e., DB::Get) and the write (i.e., DB::Put)
   // are inherently "atomic" because only one db can be opened at a
-  // time, so there can not be any writes that occur concurrently.
+  // time, so there cannot be any writes that occur concurrently.
 
   Try<bool> result = write(entry);
 
@@ -207,7 +207,7 @@ Future<bool> LevelDBStorageProcess::expunge(const Entry& entry)
 
   // Note that the read (i.e., DB::Get) and DB::Delete are inherently
   // "atomic" because only one db can be opened at a time, so there
-  // can not be any writes that occur concurrently.
+  // cannot be any writes that occur concurrently.
 
   leveldb::WriteOptions options;
   options.sync = true;

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/tests/master_authorization_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_authorization_tests.cpp b/src/tests/master_authorization_tests.cpp
index eaf0f01..5d08ebc 100644
--- a/src/tests/master_authorization_tests.cpp
+++ b/src/tests/master_authorization_tests.cpp
@@ -1993,7 +1993,7 @@ TYPED_TEST(MasterAuthorizerTest, ViewFlags)
   }
 
   {
-    // Second default principal can not see the flags.
+    // Second default principal cannot see the flags.
     mesos::ACL::ViewFlags* acl = acls.add_view_flags();
     acl->mutable_principals()->add_values(DEFAULT_CREDENTIAL_2.principal());
     acl->mutable_flags()->set_type(ACL::Entity::NONE);

http://git-wip-us.apache.org/repos/asf/mesos/blob/d4492f3e/src/tests/slave_authorization_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/slave_authorization_tests.cpp b/src/tests/slave_authorization_tests.cpp
index 6f120b6..20bb712 100644
--- a/src/tests/slave_authorization_tests.cpp
+++ b/src/tests/slave_authorization_tests.cpp
@@ -280,7 +280,7 @@ TYPED_TEST(SlaveAuthorizerTest, ViewFlags)
   }
 
   {
-    // Second default principal can not see the flags.
+    // Second default principal cannot see the flags.
     mesos::ACL::ViewFlags* acl = acls.add_view_flags();
     acl->mutable_principals()->add_values(DEFAULT_CREDENTIAL_2.principal());
     acl->mutable_flags()->set_type(ACL::Entity::NONE);


[3/3] mesos git commit: Fixed usage of "can not" vs. "cannot" in libprocess.

Posted by an...@apache.org.
Fixed usage of "can not" vs. "cannot" in libprocess.

For style reasons, the latter should usually be preferred to the former.

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


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

Branch: refs/heads/master
Commit: 2e013890e47c30053b7b83cd205b432376589216
Parents: 891a69c
Author: Neil Conway <ne...@gmail.com>
Authored: Sun Oct 2 08:59:20 2016 -0700
Committer: Anand Mazumdar <an...@apache.org>
Committed: Sun Oct 2 08:59:20 2016 -0700

----------------------------------------------------------------------
 3rdparty/libprocess/configure.ac                | 2 +-
 3rdparty/libprocess/include/process/io.hpp      | 2 +-
 3rdparty/libprocess/src/io.cpp                  | 2 +-
 3rdparty/libprocess/src/tests/process_tests.cpp | 4 ++--
 3rdparty/libprocess/src/tests/ssl_tests.cpp     | 4 ++--
 5 files changed, 7 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/2e013890/3rdparty/libprocess/configure.ac
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/configure.ac b/3rdparty/libprocess/configure.ac
index bc0e6ab..f3033e3 100644
--- a/3rdparty/libprocess/configure.ac
+++ b/3rdparty/libprocess/configure.ac
@@ -84,7 +84,7 @@ AC_ARG_ENABLE([debug],
 AC_ARG_ENABLE([install],
               AS_HELP_STRING([--enable-install],
                              [install libprocess]),
-              [AC_MSG_ERROR([libprocess can not currently be installed])])
+              [AC_MSG_ERROR([libprocess cannot currently be installed])])
 
 AC_ARG_ENABLE([libevent],
               AS_HELP_STRING([--enable-libevent],

http://git-wip-us.apache.org/repos/asf/mesos/blob/2e013890/3rdparty/libprocess/include/process/io.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/io.hpp b/3rdparty/libprocess/include/process/io.hpp
index fed246b..eec5efd 100644
--- a/3rdparty/libprocess/include/process/io.hpp
+++ b/3rdparty/libprocess/include/process/io.hpp
@@ -166,7 +166,7 @@ Future<size_t> peek(int fd, void* data, size_t size, size_t limit);
  * upper bound for the size of the data to peek. It does not wait
  * until the specified amount of bytes is peeked. It returns as soon
  * as some amount of data becomes available.
- * It can not concatenate data from subsequent peeks because MSG_PEEK
+ * It cannot concatenate data from subsequent peeks because MSG_PEEK
  * has known limitations when it comes to spanning message boundaries.
  *
  * **NOTE**: this function will return an error if the limit is

http://git-wip-us.apache.org/repos/asf/mesos/blob/2e013890/3rdparty/libprocess/src/io.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/io.cpp b/3rdparty/libprocess/src/io.cpp
index e44ba3a..d930cee 100644
--- a/3rdparty/libprocess/src/io.cpp
+++ b/3rdparty/libprocess/src/io.cpp
@@ -598,7 +598,7 @@ Future<string> peek(int fd, size_t limit)
   return io::peek(fd, data.get(), BUFFERED_READ_SIZE, limit)
     .then([=](size_t length) -> Future<string> {
       // At this point we have to return whatever data we were able to
-      // peek, because we can not rely on peeking across message
+      // peek, because we cannot rely on peeking across message
       // boundaries.
       return string(data.get(), length);
     });

http://git-wip-us.apache.org/repos/asf/mesos/blob/2e013890/3rdparty/libprocess/src/tests/process_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/tests/process_tests.cpp b/3rdparty/libprocess/src/tests/process_tests.cpp
index b8c393f..3936f47 100644
--- a/3rdparty/libprocess/src/tests/process_tests.cpp
+++ b/3rdparty/libprocess/src/tests/process_tests.cpp
@@ -1605,7 +1605,7 @@ TEST(ProcessTest, Defers)
   }
 
 //   {
-//     // CAN NOT DO IN CLANG!
+//     // CANNOT DO IN CLANG!
 //     std::function<void(string)> f =
 //       defer(std::bind(baz, std::placeholders::_1));
 
@@ -1617,7 +1617,7 @@ TEST(ProcessTest, Defers)
 //   }
 
 //   {
-//     // CAN NOT DO WITH GCC OR CLANG!
+//     // CANNOT DO WITH GCC OR CLANG!
 //     std::function<int(int)> f =
 //       defer(std::bind(baz, std::placeholders::_1));
 //   }

http://git-wip-us.apache.org/repos/asf/mesos/blob/2e013890/3rdparty/libprocess/src/tests/ssl_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/tests/ssl_tests.cpp b/3rdparty/libprocess/src/tests/ssl_tests.cpp
index a5ac039..55c8c30 100644
--- a/3rdparty/libprocess/src/tests/ssl_tests.cpp
+++ b/3rdparty/libprocess/src/tests/ssl_tests.cpp
@@ -500,7 +500,7 @@ TEST_F(SSLTest, ValidDowngrade)
 }
 
 
-// Ensure we can NOT communicate between a POLL based socket and an
+// Ensure we CANNOT communicate between a POLL based socket and an
 // SSL socket if 'SSL_SUPPORT_DOWNGRADE' is not enabled.
 TEST_F(SSLTest, NoValidDowngrade)
 {
@@ -571,7 +571,7 @@ TEST_F(SSLTest, ValidDowngradeEachProtocol)
 }
 
 
-// For each protocol: ensure we can NOT communicate between a POLL
+// For each protocol: ensure we CANNOT communicate between a POLL
 // based socket and an SSL socket if 'SSL_SUPPORT_DOWNGRADE' is not
 // enabled.
 TEST_F(SSLTest, NoValidDowngradeEachProtocol)


[2/3] mesos git commit: Fixed usage of "can not" vs. "cannot" in stout.

Posted by an...@apache.org.
Fixed usage of "can not" vs. "cannot" in stout.

For style reasons, the latter should usually be preferred to the former.

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


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

Branch: refs/heads/master
Commit: 891a69c1c7f317a86ca1383e5ce857b93007388d
Parents: d4492f3
Author: Neil Conway <ne...@gmail.com>
Authored: Sun Oct 2 08:59:14 2016 -0700
Committer: Anand Mazumdar <an...@apache.org>
Committed: Sun Oct 2 08:59:14 2016 -0700

----------------------------------------------------------------------
 3rdparty/stout/configure.ac            | 2 +-
 3rdparty/stout/include/stout/flags.hpp | 4 ++--
 2 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/891a69c1/3rdparty/stout/configure.ac
----------------------------------------------------------------------
diff --git a/3rdparty/stout/configure.ac b/3rdparty/stout/configure.ac
index 2236a2d..527188a 100644
--- a/3rdparty/stout/configure.ac
+++ b/3rdparty/stout/configure.ac
@@ -83,7 +83,7 @@ AC_ARG_ENABLE([debug],
 AC_ARG_ENABLE([install],
               AS_HELP_STRING([--enable-install],
                              [install stout]),
-              [AC_MSG_ERROR([stout can not currently be installed])])
+              [AC_MSG_ERROR([stout cannot currently be installed])])
 
 AC_ARG_ENABLE([optimize],
               AS_HELP_STRING([--enable-optimize],

http://git-wip-us.apache.org/repos/asf/mesos/blob/891a69c1/3rdparty/stout/include/stout/flags.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/flags.hpp b/3rdparty/stout/include/stout/flags.hpp
index bc4684d..21257b7 100644
--- a/3rdparty/stout/include/stout/flags.hpp
+++ b/3rdparty/stout/include/stout/flags.hpp
@@ -64,12 +64,12 @@
 //
 // "Fail early, fail often":
 //
-// You can not add duplicate flags, this is checked for you at compile
+// You cannot add duplicate flags, this is checked for you at compile
 // time for composite flags (e.g., Flag<MyFlags1, MyFlags2>) and also
 // checked at runtime for any other flags added via inheritance or
 // Flags::add(...).
 //
-// Flags that can not be loaded (e.g., attempting to use the 'no-'
+// Flags that cannot be loaded (e.g., attempting to use the 'no-'
 // prefix for a flag that is not boolean) will print a message to
 // standard error and abort the process.