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:54 UTC

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

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)
 {