You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mesos.apache.org by ne...@apache.org on 2017/03/29 21:23:52 UTC

[1/3] mesos git commit: Fixed typos in libprocess.

Repository: mesos
Updated Branches:
  refs/heads/master 5b12abb01 -> 8c4e5f190


Fixed typos in libprocess.


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

Branch: refs/heads/master
Commit: 22cc80ad71187afcc0846e777f354c11f095e38d
Parents: 5b12abb
Author: Neil Conway <ne...@gmail.com>
Authored: Wed Mar 29 14:12:36 2017 -0700
Committer: Neil Conway <ne...@gmail.com>
Committed: Wed Mar 29 14:12:36 2017 -0700

----------------------------------------------------------------------
 3rdparty/libprocess/include/process/dispatch.hpp | 2 +-
 3rdparty/libprocess/include/process/future.hpp   | 2 +-
 3rdparty/libprocess/include/process/http.hpp     | 2 +-
 3rdparty/libprocess/include/process/socket.hpp   | 2 +-
 3rdparty/libprocess/include/process/timer.hpp    | 2 +-
 3rdparty/libprocess/src/http.cpp                 | 8 ++++----
 3rdparty/libprocess/src/io.cpp                   | 4 ++--
 3rdparty/libprocess/src/subprocess_windows.cpp   | 2 +-
 3rdparty/libprocess/src/tests/future_tests.cpp   | 2 +-
 9 files changed, 13 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/include/process/dispatch.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/dispatch.hpp b/3rdparty/libprocess/include/process/dispatch.hpp
index 1edaf8b..3a07938 100644
--- a/3rdparty/libprocess/include/process/dispatch.hpp
+++ b/3rdparty/libprocess/include/process/dispatch.hpp
@@ -48,7 +48,7 @@ namespace process {
 // routine itself creates a promise that is passed as an argument to a
 // partially applied 'dispatcher' function (defined below). The
 // dispatcher routines get passed to the actual process via an
-// internal routine called, not suprisingly, 'dispatch', defined
+// internal routine called, not surprisingly, 'dispatch', defined
 // below:
 
 namespace internal {

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/include/process/future.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/future.hpp b/3rdparty/libprocess/include/process/future.hpp
index ec7ef22..cce9505 100644
--- a/3rdparty/libprocess/include/process/future.hpp
+++ b/3rdparty/libprocess/include/process/future.hpp
@@ -224,7 +224,7 @@ private:
         }));
   }
 
-  // This is the less prefered `onReady`, we prefer the `onReady` method which
+  // This is the less preferred `onReady`, we prefer the `onReady` method which
   // has `f` taking a `const T&` parameter. Unfortunately, to complicate
   // matters, if `F` is the result of a `std::bind` expression we need to SFINAE
   // out this version of `onReady` and force the use of the preferred `onReady`

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/include/process/http.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/http.hpp b/3rdparty/libprocess/include/process/http.hpp
index 9b89d31..5c013ca 100644
--- a/3rdparty/libprocess/include/process/http.hpp
+++ b/3rdparty/libprocess/include/process/http.hpp
@@ -985,7 +985,7 @@ Future<Nothing> serve(
 // handler.
 //
 // Returns `Nothing` after serving has completed, either because (1) a
-// failure occured receiving requests or sending responses or (2) the
+// failure occurred receiving requests or sending responses or (2) the
 // HTTP connection was not persistent (i.e., a 'Connection: close'
 // header existed either on the request or the response) or (3)
 // serving was discarded.

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/include/process/socket.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/socket.hpp b/3rdparty/libprocess/include/process/socket.hpp
index 47a2c9d..42287c1 100644
--- a/3rdparty/libprocess/include/process/socket.hpp
+++ b/3rdparty/libprocess/include/process/socket.hpp
@@ -234,7 +234,7 @@ protected:
  * An abstraction around a socket (file descriptor).
  *
  * Provides reference counting such that the socket is only closed
- * (and thus, has the possiblity of being reused) after there are no
+ * (and thus, has the possibility of being reused) after there are no
  * more references.
  */
 template <typename AddressType>

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/include/process/timer.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/timer.hpp b/3rdparty/libprocess/include/process/timer.hpp
index 3dabb74..6df57f4 100644
--- a/3rdparty/libprocess/include/process/timer.hpp
+++ b/3rdparty/libprocess/include/process/timer.hpp
@@ -75,7 +75,7 @@ private:
   // there is one). We don't store a pointer to the process because we
   // can't dereference it since it might no longer be valid. (Instead,
   // the PID can be used internally to check if the process is still
-  // valid and get a refernce to it.)
+  // valid and get a reference to it.)
   process::UPID pid;
 
   lambda::function<void()> thunk;

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/src/http.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/http.cpp b/3rdparty/libprocess/src/http.cpp
index e17ad22..9789607 100644
--- a/3rdparty/libprocess/src/http.cpp
+++ b/3rdparty/libprocess/src/http.cpp
@@ -206,7 +206,7 @@ Try<URL> URL::parse(const string& urlString)
   }
 
   // If path is specified in the URL, try to capture the host and path
-  // seperately.
+  // separately.
   string host = urlPath;
   string path = "/";
   if (pathPos != string::npos) {
@@ -1662,7 +1662,7 @@ Future<Nothing> stream(
     .then([=]() {
       return stream(socket, response.reader.get());
     })
-    // Regardless of whether `send` or `stream` completed succesfully
+    // Regardless of whether `send` or `stream` completed successfully
     // or failed we close the reader so any writers will be notified.
     .onAny([=]() mutable {
       response.reader->close();
@@ -1818,7 +1818,7 @@ Future<Nothing> serve(
         // Either:
         //
         //   (1) An EOF was received.
-        //   (2) A failure occured while receiving.
+        //   (2) A failure occurred while receiving.
         //   (3) Receiving was discarded (likely because serving was
         //       discarded).
         //
@@ -1842,7 +1842,7 @@ Future<Nothing> serve(
         //
         //   (1) HTTP connection is not meant to be persistent or
         //       there are no more items expected in the pipeline.
-        //   (2) A failure occured while sending.
+        //   (2) A failure occurred while sending.
         //   (3) Sending was discarded (likely because serving was
         //       discarded).
         //

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/src/io.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/io.cpp b/3rdparty/libprocess/src/io.cpp
index a1e8da3..97f2b17 100644
--- a/3rdparty/libprocess/src/io.cpp
+++ b/3rdparty/libprocess/src/io.cpp
@@ -213,7 +213,7 @@ Future<string> read(int_fd fd)
   process::initialize();
 
   // Get our own copy of the file descriptor so that we're in control
-  // of the lifetime and don't crash if/when someone by accidently
+  // of the lifetime and don't crash if/when someone accidentally
   // closes the file descriptor before discarding this future. We can
   // also make sure it's non-blocking and will close-on-exec. Start by
   // checking we've got a "valid" file descriptor before dup'ing.
@@ -274,7 +274,7 @@ Future<Nothing> write(int_fd fd, const string& data)
   process::initialize();
 
   // Get our own copy of the file descriptor so that we're in control
-  // of the lifetime and don't crash if/when someone by accidently
+  // of the lifetime and don't crash if/when someone accidentally
   // closes the file descriptor before discarding this future. We can
   // also make sure it's non-blocking and will close-on-exec. Start by
   // checking we've got a "valid" file descriptor before dup'ing.

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/src/subprocess_windows.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/subprocess_windows.cpp b/3rdparty/libprocess/src/subprocess_windows.cpp
index 839212b..cc71fbd 100644
--- a/3rdparty/libprocess/src/subprocess_windows.cpp
+++ b/3rdparty/libprocess/src/subprocess_windows.cpp
@@ -161,7 +161,7 @@ static Try<HANDLE> createOutputFile(const string& path)
 }  // namespace internal {
 
 // Opens an inheritable pipe[1] represented as a pair of file handles. On
-// success, the first handle returned recieves the 'read' handle of the pipe,
+// success, the first handle returned receives the 'read' handle of the pipe,
 // while the second receives the 'write' handle. The pipe handles can then be
 // passed to a child process, as exemplified in [2].
 //

http://git-wip-us.apache.org/repos/asf/mesos/blob/22cc80ad/3rdparty/libprocess/src/tests/future_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/tests/future_tests.cpp b/3rdparty/libprocess/src/tests/future_tests.cpp
index 2fc2bd4..f21361e 100644
--- a/3rdparty/libprocess/src/tests/future_tests.cpp
+++ b/3rdparty/libprocess/src/tests/future_tests.cpp
@@ -259,7 +259,7 @@ TEST(FutureTest, After2)
 
 
 // Verifies that a a future does not leak memory after calling
-// `after()`. This behavior ocurred because a future indirectly
+// `after()`. This behavior occurred because a future indirectly
 // kept a reference counted pointer to itself.
 TEST(FutureTest, After3)
 {


[3/3] mesos git commit: Fixed typos in Mesos.

Posted by ne...@apache.org.
Fixed typos in Mesos.


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

Branch: refs/heads/master
Commit: 8c4e5f190c75dc845a98238e480c32e6bce7cf71
Parents: 43ef2cd
Author: Neil Conway <ne...@gmail.com>
Authored: Wed Mar 29 14:13:27 2017 -0700
Committer: Neil Conway <ne...@gmail.com>
Committed: Wed Mar 29 14:13:27 2017 -0700

----------------------------------------------------------------------
 src/docker/docker.cpp                                        | 2 +-
 src/launcher/executor.cpp                                    | 2 +-
 src/linux/cgroups.hpp                                        | 2 +-
 src/linux/fs.hpp                                             | 2 +-
 src/linux/routing/filter/internal.hpp                        | 2 +-
 src/master/http.cpp                                          | 2 +-
 src/master/main.cpp                                          | 2 +-
 src/slave/containerizer/docker.cpp                           | 4 ++--
 src/slave/containerizer/fetcher.cpp                          | 2 +-
 .../containerizer/mesos/isolators/cgroups/subsystem.hpp      | 2 +-
 src/slave/containerizer/mesos/launch.cpp                     | 2 +-
 src/slave/containerizer/mesos/mount.hpp                      | 2 +-
 src/slave/containerizer/mesos/provisioner/provisioner.cpp    | 8 ++++----
 src/slave/validation.hpp                                     | 2 +-
 src/tests/authorization_tests.cpp                            | 2 +-
 src/tests/containerizer/docker_containerizer_tests.cpp       | 4 ++--
 src/tests/containerizer/provisioner_appc_tests.cpp           | 2 +-
 src/tests/containerizer/provisioner_docker_tests.cpp         | 2 +-
 src/tests/mesos.hpp                                          | 2 +-
 src/tests/reservation_endpoints_tests.cpp                    | 2 +-
 20 files changed, 25 insertions(+), 25 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/docker/docker.cpp
----------------------------------------------------------------------
diff --git a/src/docker/docker.cpp b/src/docker/docker.cpp
index 9de19d4..3b934d9 100755
--- a/src/docker/docker.cpp
+++ b/src/docker/docker.cpp
@@ -927,7 +927,7 @@ Future<Option<int>> Docker::run(
   //
   // TODO(bmahler): Determine a way to redirect stderr while still
   // capturing the stderr when 'docker run' itself fails. E.g. we
-  // could use 'docker logs' in conjuction with a "detached" form
+  // could use 'docker logs' in conjunction with a "detached" form
   // of 'docker run' to isolate 'docker run' failure messages from
   // the container stderr.
   return s->status();

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/launcher/executor.cpp
----------------------------------------------------------------------
diff --git a/src/launcher/executor.cpp b/src/launcher/executor.cpp
index a4bac9d..8bd266e 100644
--- a/src/launcher/executor.cpp
+++ b/src/launcher/executor.cpp
@@ -827,7 +827,7 @@ private:
         None(),
         message);
 
-    // Indicate that a kill occured due to a failing health check.
+    // Indicate that a kill occurred due to a failing health check.
     if (killed && killedByHealthCheck) {
       status.set_healthy(false);
     }

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/linux/cgroups.hpp
----------------------------------------------------------------------
diff --git a/src/linux/cgroups.hpp b/src/linux/cgroups.hpp
index cfce09c..eaf0dca 100644
--- a/src/linux/cgroups.hpp
+++ b/src/linux/cgroups.hpp
@@ -471,7 +471,7 @@ struct Stats
 //
 // @param   hierarchy   hierarchy for the 'cpuacct' subsystem.
 // @param   cgroup      cgroup for a given process.
-// @return  Some<Stats> if sucessful.
+// @return  Some<Stats> if successful.
 //          Error in case of any error during processing.
 Try<Stats> stat(
     const std::string& hierarchy,

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/linux/fs.hpp
----------------------------------------------------------------------
diff --git a/src/linux/fs.hpp b/src/linux/fs.hpp
index 4da4caf..cbc8bf7 100644
--- a/src/linux/fs.hpp
+++ b/src/linux/fs.hpp
@@ -374,7 +374,7 @@ Try<Nothing> pivot_root(const std::string& newRoot, const std::string& putOld);
 
 namespace chroot {
 
-// Enter a 'chroot' enviroment. The caller should be in a new mount
+// Enter a 'chroot' environment. The caller should be in a new mount
 // namespace. Basic configuration of special filesystems and device
 // nodes is performed. Any mounts to the current root will be
 // unmounted.

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/linux/routing/filter/internal.hpp
----------------------------------------------------------------------
diff --git a/src/linux/routing/filter/internal.hpp b/src/linux/routing/filter/internal.hpp
index dc4b8f9..b22a818 100644
--- a/src/linux/routing/filter/internal.hpp
+++ b/src/linux/routing/filter/internal.hpp
@@ -440,7 +440,7 @@ template <typename Classifier>
 Result<Filter<Classifier>> decodeFilter(const Netlink<struct rtnl_cls>& cls)
 {
   // If the handle of the libnl filer is 0, it means that it is an
-  // internal filter, therefore is definitly not created by us.
+  // internal filter, therefore is definitely not created by us.
   if (rtnl_tc_get_handle(TC_CAST(cls.get())) == 0) {
     return None();
   }

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/master/http.cpp
----------------------------------------------------------------------
diff --git a/src/master/http.cpp b/src/master/http.cpp
index 96409f6..6cf9d35 100644
--- a/src/master/http.cpp
+++ b/src/master/http.cpp
@@ -456,7 +456,7 @@ string Master::Http::API_HELP()
     TLDR(
         "Endpoint for API calls against the master."),
     DESCRIPTION(
-        "Returns 200 OK when the request was processed sucessfully.",
+        "Returns 200 OK when the request was processed successfully.",
         "Returns 307 TEMPORARY_REDIRECT redirect to the leading master when",
         "current master is not the leader.",
         "Returns 503 SERVICE_UNAVAILABLE if the leading master cannot be",

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/master/main.cpp
----------------------------------------------------------------------
diff --git a/src/master/main.cpp b/src/master/main.cpp
index fa7ba13..3d2176c 100644
--- a/src/master/main.cpp
+++ b/src/master/main.cpp
@@ -202,7 +202,7 @@ int main(int argc, char** argv)
   // * Allocator.
   // * Registry storage.
   // * State.
-  // * Master contendor.
+  // * Master contender.
   // * Master detector.
   // * Authorizer.
   // * Slave removal rate limiter.

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/docker.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/docker.cpp b/src/slave/containerizer/docker.cpp
index 7951ed1..ad9ab84 100644
--- a/src/slave/containerizer/docker.cpp
+++ b/src/slave/containerizer/docker.cpp
@@ -1408,7 +1408,7 @@ Future<pid_t> DockerContainerizerProcess::launchExecutorProcess(
   // Prepare environment variables for the executor.
   map<string, string> environment = container->environment;
 
-  // Include any enviroment variables from ExecutorInfo.
+  // Include any environment variables from ExecutorInfo.
   foreach (const Environment::Variable& variable,
            container->executor.command().environment().variables()) {
     environment[variable.name()] = variable.value();
@@ -2244,7 +2244,7 @@ void DockerContainerizerProcess::__destroy(
     // means it's possible that the container is still going to be
     // running after we return! We either need to have a periodic
     // "garbage collector", or we need to retry the Docker::kill
-    // indefinitely until it has been sucessful.
+    // indefinitely until it has been successful.
 
     string failure = "Failed to kill the Docker container: " +
                      (kill.isFailed() ? kill.failure() : "discarded future");

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/fetcher.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/fetcher.cpp b/src/slave/containerizer/fetcher.cpp
index 34a5fbb..a910fea 100644
--- a/src/slave/containerizer/fetcher.cpp
+++ b/src/slave/containerizer/fetcher.cpp
@@ -762,7 +762,7 @@ Future<Nothing> FetcherProcess::run(
 // here is conditionally compiled out on Windows.
 #ifndef __WINDOWS__
   if (user.isSome()) {
-    // TODO(megha.sharma): Fetcher should not create seperate stdout/stderr
+    // TODO(megha.sharma): Fetcher should not create separate stdout/stderr
     // files but rather use FDs prepared by the container logger.
     // See MESOS-6271 for more details.
     Try<Nothing> chownOut = os::chown(

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/mesos/isolators/cgroups/subsystem.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/isolators/cgroups/subsystem.hpp b/src/slave/containerizer/mesos/isolators/cgroups/subsystem.hpp
index bbc208b..65c1e47 100644
--- a/src/slave/containerizer/mesos/isolators/cgroups/subsystem.hpp
+++ b/src/slave/containerizer/mesos/isolators/cgroups/subsystem.hpp
@@ -153,7 +153,7 @@ public:
 
   /**
    * Clean up the cgroups subsystem for the associated container. It
-   * will be called when destruction to ensure everyting be cleanup.
+   * will be called when destruction to ensure everything be cleanup.
    * Similar to the isolator `cleanup`, it's likely that the `cleanup`
    * for the subsystem is called for unknown containers (see
    * MESOS-6059). We should ignore the cleanup request if the

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/mesos/launch.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/launch.cpp b/src/slave/containerizer/mesos/launch.cpp
index 715500d..395394f 100644
--- a/src/slave/containerizer/mesos/launch.cpp
+++ b/src/slave/containerizer/mesos/launch.cpp
@@ -727,7 +727,7 @@ int MesosContainerizerLaunch::execute()
       int status = 0;
       Result<pid_t> waitpid = None();
 
-      // Reap all decendants, but only continue once we reap the
+      // Reap all descendants, but only continue once we reap the
       // process we just launched.
       while (true) {
         waitpid = os::waitpid(-1, &status, 0);

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/mesos/mount.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/mount.hpp b/src/slave/containerizer/mesos/mount.hpp
index f6fbe04..038426d 100644
--- a/src/slave/containerizer/mesos/mount.hpp
+++ b/src/slave/containerizer/mesos/mount.hpp
@@ -24,7 +24,7 @@ namespace mesos {
 namespace internal {
 namespace slave {
 
-// "mount" subcommand functions similiarly to the mount program.
+// "mount" subcommand functions similarly to the mount program.
 // However, this subcommand is necessary because of the following reasons:
 // - `mount --make-rslave <dir>` doesn't work on ubuntu 14.04 due to an existing
 //    bug.

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/containerizer/mesos/provisioner/provisioner.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/provisioner/provisioner.cpp b/src/slave/containerizer/mesos/provisioner/provisioner.cpp
index 478ab09..be45fc5 100644
--- a/src/slave/containerizer/mesos/provisioner/provisioner.cpp
+++ b/src/slave/containerizer/mesos/provisioner/provisioner.cpp
@@ -497,13 +497,13 @@ Future<bool> ProvisionerProcess::destroy(const ContainerID& containerId)
   // 2. Containerizer `recover` to destroy known orphans.
   // 3. Containerizer `destroy` on one specific container.
   //
-  // NOTE: For (2) and (3), we expect the container being destory
+  // NOTE: For (2) and (3), we expect the container being destroyed
   // has no any child contain remain running. However, for case (1),
   // if the container runtime directory does not survive after the
   // machine reboots and the provisioner directory under the agent
   // work dir still exists, all containers will be regarded as
-  // unkown containers and will be destroyed. In this case, a parent
-  // container may be destoryed before its child containers are
+  // unknown containers and will be destroyed. In this case, a parent
+  // container may be destroyed before its child containers are
   // cleaned up. So we have to make `destroy()` recursively for
   // this particular case.
   //
@@ -543,7 +543,7 @@ Future<bool> ProvisionerProcess::_destroy(
     ++metrics.remove_container_errors;
 
     return Failure(
-        "Failed to destory nested containers: " +
+        "Failed to destroy nested containers: " +
         strings::join("; ", errors));
   }
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/slave/validation.hpp
----------------------------------------------------------------------
diff --git a/src/slave/validation.hpp b/src/slave/validation.hpp
index 8a7f297..3a278e4 100644
--- a/src/slave/validation.hpp
+++ b/src/slave/validation.hpp
@@ -38,7 +38,7 @@ Option<Error> validateContainerId(const ContainerID& containerId);
 namespace agent {
 namespace call {
 
-// Validates that a agent:Call is well-formed.
+// Validates that an agent::Call is well-formed.
 // TODO(bmahler): Add unit tests.
 Option<Error> validate(
     const mesos::agent::Call& call,

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/authorization_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/authorization_tests.cpp b/src/tests/authorization_tests.cpp
index cd15add..9f63682 100644
--- a/src/tests/authorization_tests.cpp
+++ b/src/tests/authorization_tests.cpp
@@ -3262,7 +3262,7 @@ TYPED_TEST(AuthorizationTest, LaunchNestedContainers)
   {
     // "foo" principal cannot launch nested containers as commands
     // under any parent container. He may still get to launch nested
-    // container if he is allowed to do so for executors wich run as
+    // container if he is allowed to do so for executors which run as
     // a given user for which "foo" has permissions and the session
     // uses a `container_info` instead of a `command_info`.
     mesos::ACL::LaunchNestedContainerAsUser* acl =

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/containerizer/docker_containerizer_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer/docker_containerizer_tests.cpp b/src/tests/containerizer/docker_containerizer_tests.cpp
index 2036cd2..4eef399 100644
--- a/src/tests/containerizer/docker_containerizer_tests.cpp
+++ b/src/tests/containerizer/docker_containerizer_tests.cpp
@@ -3073,8 +3073,8 @@ TEST_F(DockerContainerizerTest, ROOT_DOCKER_NC_PortMapping)
 
 // This test verifies that sandbox with ':' in the path can still
 // run successfully. This a limitation of the Docker CLI where
-// the volume map parameter treats colons (:) as seperators,
-// and incorrectly seperates the sandbox directory.
+// the volume map parameter treats colons (:) as separators,
+// and incorrectly separates the sandbox directory.
 TEST_F(DockerContainerizerTest, ROOT_DOCKER_LaunchSandboxWithColon)
 {
   Try<Owned<cluster::Master>> master = StartMaster();

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/containerizer/provisioner_appc_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer/provisioner_appc_tests.cpp b/src/tests/containerizer/provisioner_appc_tests.cpp
index 4342793..cba83c6 100644
--- a/src/tests/containerizer/provisioner_appc_tests.cpp
+++ b/src/tests/containerizer/provisioner_appc_tests.cpp
@@ -666,7 +666,7 @@ public:
 private:
   // TODO(jojy): Currently hard-codes the images dierctory name.
   // Consider parameterizing the directory name. This could be done
-  // by removing the 'const' ness of teh variable and adding mutator.
+  // by removing the 'const' ness of the variable and adding mutator.
   const string imagesDirName;
 };
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/containerizer/provisioner_docker_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer/provisioner_docker_tests.cpp b/src/tests/containerizer/provisioner_docker_tests.cpp
index 8c295fe..dbbc353 100644
--- a/src/tests/containerizer/provisioner_docker_tests.cpp
+++ b/src/tests/containerizer/provisioner_docker_tests.cpp
@@ -182,7 +182,7 @@ protected:
 
 
 // This test verifies that a locally stored Docker image in the form of a
-// tar achive created from a 'docker save' command can be unpacked and
+// tar archive created from a 'docker save' command can be unpacked and
 // stored in the proper locations accessible to the Docker provisioner.
 TEST_F(ProvisionerDockerLocalStoreTest, LocalStoreTestWithTar)
 {

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/mesos.hpp
----------------------------------------------------------------------
diff --git a/src/tests/mesos.hpp b/src/tests/mesos.hpp
index a7d33ad..fe897c1 100644
--- a/src/tests/mesos.hpp
+++ b/src/tests/mesos.hpp
@@ -259,7 +259,7 @@ protected:
 
 private:
   // Base hierarchy for separately mounted cgroup controllers, e.g., if the
-  // base hierachy is /sys/fs/cgroup then each controller will be mounted to
+  // base hierarchy is /sys/fs/cgroup then each controller will be mounted to
   // /sys/fs/cgroup/{controller}/.
   std::string baseHierarchy;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/8c4e5f19/src/tests/reservation_endpoints_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/reservation_endpoints_tests.cpp b/src/tests/reservation_endpoints_tests.cpp
index 6cda3a6..cc8499a 100644
--- a/src/tests/reservation_endpoints_tests.cpp
+++ b/src/tests/reservation_endpoints_tests.cpp
@@ -1634,7 +1634,7 @@ TEST_F(ReservationEndpointsTest, DifferentPrincipalsSameRole)
 
 // This test verifies that dynamic reservations are reflected in the
 // agent's "/state" endpoint. Separately exposing reservations from
-// the agent's endpoint is necessary because it's not a gurantee that
+// the agent's endpoint is necessary because it's not a guarantee that
 // it matches the master's versions.
 TEST_F(ReservationEndpointsTest, AgentStateEndpointResources)
 {


[2/3] mesos git commit: Fixed typos in stout.

Posted by ne...@apache.org.
Fixed typos in stout.


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

Branch: refs/heads/master
Commit: 43ef2cd58a1e0d82f3835d7dc49b247e6fc849d0
Parents: 22cc80a
Author: Neil Conway <ne...@gmail.com>
Authored: Wed Mar 29 14:13:03 2017 -0700
Committer: Neil Conway <ne...@gmail.com>
Committed: Wed Mar 29 14:13:03 2017 -0700

----------------------------------------------------------------------
 3rdparty/stout/include/stout/check.hpp               | 2 +-
 3rdparty/stout/include/stout/os/posix/killtree.hpp   | 2 +-
 3rdparty/stout/include/stout/os/posix/socket.hpp     | 2 +-
 3rdparty/stout/include/stout/os/raw/environment.hpp  | 2 +-
 3rdparty/stout/include/stout/os/windows/killtree.hpp | 2 +-
 3rdparty/stout/include/stout/os/windows/socket.hpp   | 2 +-
 6 files changed, 6 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/check.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/check.hpp b/3rdparty/stout/include/stout/check.hpp
index 6a98519..e3cabd4 100644
--- a/3rdparty/stout/include/stout/check.hpp
+++ b/3rdparty/stout/include/stout/check.hpp
@@ -27,7 +27,7 @@
 #include <stout/some.hpp>
 #include <stout/try.hpp>
 
-// A generic macro to faciliate definitions of CHECK_*, akin to CHECK.
+// A generic macro to facilitate definitions of CHECK_*, akin to CHECK.
 // This appends the error if possible to the end of the log message,
 // so there's no need to append the error message explicitly.
 // To define a new CHECK_*, provide the name, the function that performs the

http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/os/posix/killtree.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/os/posix/killtree.hpp b/3rdparty/stout/include/stout/os/posix/killtree.hpp
index f47f0d8..9f18a48 100644
--- a/3rdparty/stout/include/stout/os/posix/killtree.hpp
+++ b/3rdparty/stout/include/stout/os/posix/killtree.hpp
@@ -49,7 +49,7 @@ inline Try<std::list<ProcessTree>> pstrees(
 // Note that if the process 'pid' has exited we'll signal the process
 // tree(s) rooted at pids in the group or session led by the process
 // if groups = true or sessions = true, respectively.
-// Returns the process trees that were succesfully or unsuccessfully
+// Returns the process trees that were successfully or unsuccessfully
 // signaled. Note that the process trees can be stringified.
 // TODO(benh): Allow excluding the root pid from stopping, killing,
 // and continuing so as to provide a means for expressing "kill all of

http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/os/posix/socket.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/os/posix/socket.hpp b/3rdparty/stout/include/stout/os/posix/socket.hpp
index 5a6c51d..927e7a1 100644
--- a/3rdparty/stout/include/stout/os/posix/socket.hpp
+++ b/3rdparty/stout/include/stout/os/posix/socket.hpp
@@ -29,7 +29,7 @@ using ::recv;
 using ::send;
 
 // The error indicates the last socket operation has been
-// interupted, the operation can be restarted imediately.
+// interupted, the operation can be restarted immediately.
 inline bool is_restartable_error(int error)
 {
   return (error == EINTR);

http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/os/raw/environment.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/os/raw/environment.hpp b/3rdparty/stout/include/stout/os/raw/environment.hpp
index b19dbb4..c7f889f 100644
--- a/3rdparty/stout/include/stout/os/raw/environment.hpp
+++ b/3rdparty/stout/include/stout/os/raw/environment.hpp
@@ -56,7 +56,7 @@ extern char** environ;
 //
 // NOTE: These functions were originally called `environment` and not `environ`
 // because on Windows, `environ` is a macro, and not an `extern char**` as it
-// is in the POSIX standard. The existance of this macro on Windows makes it
+// is in the POSIX standard. The existence of this macro on Windows makes it
 // impossible to use a function called `os::environ`.
 namespace os {
 namespace raw {

http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/os/windows/killtree.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/os/windows/killtree.hpp b/3rdparty/stout/include/stout/os/windows/killtree.hpp
index 2be2f8c..15b2faa 100644
--- a/3rdparty/stout/include/stout/os/windows/killtree.hpp
+++ b/3rdparty/stout/include/stout/os/windows/killtree.hpp
@@ -24,7 +24,7 @@ namespace os {
 // Terminate the process tree rooted at the specified pid.
 // Note that if the process 'pid' has exited we'll terminate the process
 // tree(s) rooted at pids.
-// Returns the process trees that were succesfully or unsuccessfully
+// Returns the process trees that were successfully or unsuccessfully
 // signaled. Note that the process trees can be stringified.
 inline Try<std::list<ProcessTree>> killtree(
     pid_t pid,

http://git-wip-us.apache.org/repos/asf/mesos/blob/43ef2cd5/3rdparty/stout/include/stout/os/windows/socket.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/stout/include/stout/os/windows/socket.hpp b/3rdparty/stout/include/stout/os/windows/socket.hpp
index 6eaf694..43f5436 100644
--- a/3rdparty/stout/include/stout/os/windows/socket.hpp
+++ b/3rdparty/stout/include/stout/os/windows/socket.hpp
@@ -93,7 +93,7 @@ inline bool wsa_cleanup()
 
 
 // The error indicates the last socket operation has been
-// interupted, the operation can be restarted imediately.
+// interupted, the operation can be restarted immediately.
 // The error will append on Windows only when the operation
 // is interupted using  `WSACancelBlockingCall`.
 inline bool is_restartable_error(int error) { return (error == WSAEINTR); }