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

[4/4] mesos git commit: Corrected usage of "it's" in Mesos.

Corrected usage of "it's" in Mesos.

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


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

Branch: refs/heads/master
Commit: 22d3f56ce10cf61b6a1f06614bd63e0943a8b769
Parents: 124f6e3
Author: Neil Conway <ne...@gmail.com>
Authored: Thu Oct 13 16:16:44 2016 -0700
Committer: Joseph Wu <jo...@apache.org>
Committed: Thu Oct 13 17:36:47 2016 -0700

----------------------------------------------------------------------
 docs/app-framework-development-guide.md          | 4 ++--
 docs/oversubscription.md                         | 2 +-
 include/mesos/executor.hpp                       | 2 +-
 include/mesos/log/log.hpp                        | 4 ++--
 src/java/src/org/apache/mesos/Executor.java      | 4 ++--
 src/linux/cgroups.hpp                            | 2 +-
 src/local/local.cpp                              | 2 +-
 src/log/replica.cpp                              | 2 +-
 src/master/main.cpp                              | 2 +-
 src/slave/containerizer/mesos/containerizer.cpp  | 2 +-
 src/slave/containerizer/mesos/linux_launcher.cpp | 2 +-
 src/slave/main.cpp                               | 2 +-
 src/tests/hierarchical_allocator_tests.cpp       | 8 ++++----
 src/tests/scheduler_http_api_tests.cpp           | 2 +-
 src/zookeeper/group.cpp                          | 2 +-
 15 files changed, 21 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/docs/app-framework-development-guide.md
----------------------------------------------------------------------
diff --git a/docs/app-framework-development-guide.md b/docs/app-framework-development-guide.md
index b419cb4..84521cd 100644
--- a/docs/app-framework-development-guide.md
+++ b/docs/app-framework-development-guide.md
@@ -329,7 +329,7 @@ Declared in `MESOS_HOME/include/mesos/executor.hpp`
 /*
  * Invoked once the executor driver has been able to successfully
  * connect with Mesos. In particular, a scheduler can pass some
- * data to it's executors through the `FrameworkInfo.ExecutorInfo`'s
+ * data to its executors through the `FrameworkInfo.ExecutorInfo`'s
  * data field.
  */
 virtual void registered(
@@ -375,7 +375,7 @@ virtual void killTask(ExecutorDriver* driver, const TaskID& taskId);
 virtual void frameworkMessage(ExecutorDriver* driver, const std::string& data);
 
 /*
- * Invoked when the executor should terminate all of it's currently
+ * Invoked when the executor should terminate all of its currently
  * running tasks. Note that after a Mesos has determined that an
  * executor has terminated any tasks that the executor did not send
  * terminal status updates for (e.g., TASK_KILLED, TASK_FINISHED,

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/docs/oversubscription.md
----------------------------------------------------------------------
diff --git a/docs/oversubscription.md b/docs/oversubscription.md
index b4e4873..ec71946 100644
--- a/docs/oversubscription.md
+++ b/docs/oversubscription.md
@@ -192,7 +192,7 @@ public:
 ~~~
 
 > NOTE The QoS Controller must not block `corrections()`. Back the QoS
-> Controller with it's own libprocess actor instead.
+> Controller with its own libprocess actor instead.
 
 The QoS Controller informs the agent that particular corrective actions need to
 be made. Each corrective action contains information about executor or task and

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/include/mesos/executor.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/executor.hpp b/include/mesos/executor.hpp
index 10be62a..68cba9e 100644
--- a/include/mesos/executor.hpp
+++ b/include/mesos/executor.hpp
@@ -70,7 +70,7 @@ class ExecutorProcess;
 // doesn't need to store a pointer to the driver itself.
 //
 // TODO(bmahler): Consider adding a usage() callback here, that
-// provides information to the executor about it's ResourceUsage.
+// provides information to the executor about its ResourceUsage.
 class Executor
 {
 public:

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/include/mesos/log/log.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/log/log.hpp b/include/mesos/log/log.hpp
index 3edb9f1..d92d7a0 100644
--- a/include/mesos/log/log.hpp
+++ b/include/mesos/log/log.hpp
@@ -172,13 +172,13 @@ public:
 
     // Attempts to append the specified data to the log. Returns the
     // new ending position of the log or 'none' if this writer has
-    // lost it's promise to exclusively write (which can be reacquired
+    // lost its promise to exclusively write (which can be reacquired
     // by invoking Writer::start).
     process::Future<Option<Position>> append(const std::string& data);
 
     // Attempts to truncate the log up to but not including the
     // specificed position. Returns the new ending position of the log
-    // or 'none' if this writer has lost it's promise to exclusively
+    // or 'none' if this writer has lost its promise to exclusively
     // write (which can be reacquired by invoking Writer::start).
     process::Future<Option<Position>> truncate(const Position& to);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/java/src/org/apache/mesos/Executor.java
----------------------------------------------------------------------
diff --git a/src/java/src/org/apache/mesos/Executor.java b/src/java/src/org/apache/mesos/Executor.java
index d80ccac..078c0c7 100644
--- a/src/java/src/org/apache/mesos/Executor.java
+++ b/src/java/src/org/apache/mesos/Executor.java
@@ -39,7 +39,7 @@ public interface Executor {
   /**
    * Invoked once the executor driver has been able to successfully
    * connect with Mesos. In particular, a scheduler can pass some
-   * data to it's executors through the {@link ExecutorInfo#getData()}
+   * data to its executors through the {@link ExecutorInfo#getData()}
    * field.
    *
    * @param driver        The executor driver that was registered and connected
@@ -123,7 +123,7 @@ public interface Executor {
   void frameworkMessage(ExecutorDriver driver, byte[] data);
 
   /**
-   * Invoked when the executor should terminate all of it's currently
+   * Invoked when the executor should terminate all of its currently
    * running tasks. Note that after Mesos has determined that an
    * executor has terminated any tasks that the executor did not send
    * terminal status updates for (e.g. TASK_KILLED, TASK_FINISHED,

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/linux/cgroups.hpp
----------------------------------------------------------------------
diff --git a/src/linux/cgroups.hpp b/src/linux/cgroups.hpp
index 3c9d9e2..cfce09c 100644
--- a/src/linux/cgroups.hpp
+++ b/src/linux/cgroups.hpp
@@ -313,7 +313,7 @@ Try<Nothing> assign(
     pid_t pid);
 
 
-// Isolate a given process specified by it's 'pid' to a given cgroup
+// Isolate a given process specified by its 'pid' to a given cgroup
 // by both creating the cgroup (recursively) if it doesn't exist and
 // then assigning the process to that cgroup.
 //

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/local/local.cpp
----------------------------------------------------------------------
diff --git a/src/local/local.cpp b/src/local/local.cpp
index 2be5bcf..2571794 100644
--- a/src/local/local.cpp
+++ b/src/local/local.cpp
@@ -310,7 +310,7 @@ PID<Master> launch(const Flags& flags, Allocator* _allocator)
       }
 
       // We don't bother keeping around the pointer to this anonymous
-      // module, when we exit that will effectively free it's memory.
+      // module, when we exit that will effectively free its memory.
       //
       // TODO(benh): We might want to add explicit finalization (and
       // maybe explicit initialization too) in order to let the module

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/log/replica.cpp
----------------------------------------------------------------------
diff --git a/src/log/replica.cpp b/src/log/replica.cpp
index 5ab7b3d..d596e61 100644
--- a/src/log/replica.cpp
+++ b/src/log/replica.cpp
@@ -391,7 +391,7 @@ void ReplicaProcess::promise(const UPID& from, const PromiseRequest& request)
 
     // If the position has been truncated, tell the proposer that it's
     // a learned no-op. This can happen when a replica has missed some
-    // truncates and it's proposer tries to fill some truncated
+    // truncates and its proposer tries to fill some truncated
     // positions on election. A learned no-op is safe since the
     // proposer should eventually learn that this position was
     // actually truncated. The action must be _learned_ so that the

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/master/main.cpp
----------------------------------------------------------------------
diff --git a/src/master/main.cpp b/src/master/main.cpp
index 4a1a8e7..9d2fd92 100644
--- a/src/master/main.cpp
+++ b/src/master/main.cpp
@@ -340,7 +340,7 @@ int main(int argc, char** argv)
     }
 
     // We don't bother keeping around the pointer to this anonymous
-    // module, when we exit that will effectively free it's memory.
+    // module, when we exit that will effectively free its memory.
     //
     // TODO(benh): We might want to add explicit finalization (and
     // maybe explicit initialization too) in order to let the module

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/slave/containerizer/mesos/containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/containerizer.cpp b/src/slave/containerizer/mesos/containerizer.cpp
index cc9e2bc..eac70d9 100644
--- a/src/slave/containerizer/mesos/containerizer.cpp
+++ b/src/slave/containerizer/mesos/containerizer.cpp
@@ -2198,7 +2198,7 @@ void MesosContainerizerProcess::______destroy(
   }
 
   // Now that we are done destroying the container we need to cleanup
-  // it's runtime directory. There are two cases to consider:
+  // its runtime directory. There are two cases to consider:
   //
   // (1) We are a nested container:
   //     In this case we should defer deletion of the runtime directory

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/slave/containerizer/mesos/linux_launcher.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/linux_launcher.cpp b/src/slave/containerizer/mesos/linux_launcher.cpp
index e8edfd2..0305d14 100644
--- a/src/slave/containerizer/mesos/linux_launcher.cpp
+++ b/src/slave/containerizer/mesos/linux_launcher.cpp
@@ -432,7 +432,7 @@ Try<pid_t> LinuxLauncherProcess::fork(
   // But since both have to happen or the child will terminate the
   // ordering is immaterial.
 
-  // Hook to extend the life of the child (and all of it's
+  // Hook to extend the life of the child (and all of its
   // descendants) using a systemd slice.
   if (systemdHierarchy.isSome()) {
     parentHooks.emplace_back(Subprocess::ParentHook([](pid_t child) {

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/slave/main.cpp
----------------------------------------------------------------------
diff --git a/src/slave/main.cpp b/src/slave/main.cpp
index 949a738..219914d 100644
--- a/src/slave/main.cpp
+++ b/src/slave/main.cpp
@@ -320,7 +320,7 @@ int main(int argc, char** argv)
     }
 
     // We don't bother keeping around the pointer to this anonymous
-    // module, when we exit that will effectively free it's memory.
+    // module, when we exit that will effectively free its memory.
     //
     // TODO(benh): We might want to add explicit finalization (and
     // maybe explicit initialization too) in order to let the module

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/tests/hierarchical_allocator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/hierarchical_allocator_tests.cpp b/src/tests/hierarchical_allocator_tests.cpp
index cae582e..2e979d7 100644
--- a/src/tests/hierarchical_allocator_tests.cpp
+++ b/src/tests/hierarchical_allocator_tests.cpp
@@ -981,7 +981,7 @@ TEST_F(HierarchicalAllocatorTest, CoarseGrained)
 
 // This test ensures that frameworks that have the same share get an
 // equal number of allocations over time (rather than the same
-// framework getting all the allocations because it's name is
+// framework getting all the allocations because its name is
 // lexicographically ordered first).
 TEST_F(HierarchicalAllocatorTest, SameShareFairness)
 {
@@ -3688,7 +3688,7 @@ TEST_P(HierarchicalAllocator_BENCHMARK_Test, AddAndUpdateSlave)
   cout << "Added " << frameworkCount << " frameworks"
        << " in " << watch.elapsed() << endl;
 
-  // Each agent has a portion of it's resources allocated to a single
+  // Each agent has a portion of its resources allocated to a single
   // framework. We round-robin through the frameworks when allocating.
   const Resources allocation = Resources::parse(
       "cpus:1;mem:128;disk:1024;"
@@ -3801,7 +3801,7 @@ TEST_P(HierarchicalAllocator_BENCHMARK_Test, DeclineOffers)
   const Resources agentResources = Resources::parse(
       "cpus:24;mem:4096;disk:4096;ports:[31000-32000]").get();
 
-  // Each agent has a portion of it's resources allocated to a single
+  // Each agent has a portion of its resources allocated to a single
   // framework. We round-robin through the frameworks when allocating.
   Resources allocation = Resources::parse("cpus:16;mem:2014;disk:1024").get();
 
@@ -4110,7 +4110,7 @@ TEST_P(HierarchicalAllocator_BENCHMARK_Test, SuppressOffers)
   const Resources agentResources = Resources::parse(
       "cpus:24;mem:4096;disk:4096;ports:[31000-32000]").get();
 
-  // Each agent has a portion of it's resources allocated to a single
+  // Each agent has a portion of its resources allocated to a single
   // framework. We round-robin through the frameworks when allocating.
   Resources allocation = Resources::parse("cpus:16;mem:1024;disk:1024").get();
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/tests/scheduler_http_api_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/scheduler_http_api_tests.cpp b/src/tests/scheduler_http_api_tests.cpp
index 80a2ef0..6390f2e 100644
--- a/src/tests/scheduler_http_api_tests.cpp
+++ b/src/tests/scheduler_http_api_tests.cpp
@@ -119,7 +119,7 @@ INSTANTIATE_TEST_CASE_P(
 
 
 // TODO(anand): Add tests for:
-// - A subscribed scheduler closes it's reader and then tries to
+// - A subscribed scheduler closes its reader and then tries to
 //  subscribe again before the framework failover timeout and should
 //  succeed.
 //

http://git-wip-us.apache.org/repos/asf/mesos/blob/22d3f56c/src/zookeeper/group.cpp
----------------------------------------------------------------------
diff --git a/src/zookeeper/group.cpp b/src/zookeeper/group.cpp
index 65a6d05..1df4b54 100644
--- a/src/zookeeper/group.cpp
+++ b/src/zookeeper/group.cpp
@@ -600,7 +600,7 @@ Result<Group::Membership> GroupProcess::doJoin(
   CHECK_EQ(state, READY);
 
   // Create a new ephemeral node to represent a new member and use the
-  // the specified data as it's contents.
+  // the specified data as its contents.
   string result;
 
   int code = zk->create(