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/01/12 00:52:48 UTC

[1/3] mesos git commit: Mesos: Fixed typos in comments and docs.

Repository: mesos
Updated Branches:
  refs/heads/master abe0bf465 -> 80c123ec5


Mesos: Fixed typos in comments and docs.

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


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

Branch: refs/heads/master
Commit: 80c123ec50e986dc10e222401e195ce57e8f24f9
Parents: fee4f2b
Author: Neil Conway <ne...@gmail.com>
Authored: Mon Jan 11 15:50:12 2016 -0800
Committer: Joris Van Remoortere <jo...@gmail.com>
Committed: Mon Jan 11 15:52:35 2016 -0800

----------------------------------------------------------------------
 docs/app-framework-development-guide.md         | 2 +-
 docs/docker-containerizer.md                    | 4 ++--
 docs/networking-for-mesos-managed-containers.md | 2 +-
 docs/scheduler-http-api.md                      | 4 ++--
 docs/upgrades.md                                | 2 +-
 include/mesos/attributes.hpp                    | 2 +-
 include/mesos/v1/attributes.hpp                 | 2 +-
 include/mesos/v1/mesos.proto                    | 6 +++---
 include/mesos/v1/scheduler/scheduler.proto      | 2 +-
 src/examples/test_authorizer_module.cpp         | 2 +-
 src/java/src/org/apache/mesos/Scheduler.java    | 2 +-
 src/master/contender.cpp                        | 2 +-
 src/master/detector.cpp                         | 2 +-
 src/slave/containerizer/docker.hpp              | 2 +-
 src/tests/active_user_test_helper.cpp           | 2 +-
 src/tests/containerizer/docker_tests.cpp        | 2 +-
 src/tests/executor_http_api_tests.cpp           | 2 +-
 src/tests/state_tests.cpp                       | 2 +-
 18 files changed, 22 insertions(+), 22 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/docs/app-framework-development-guide.md
----------------------------------------------------------------------
diff --git a/docs/app-framework-development-guide.md b/docs/app-framework-development-guide.md
index b4c53d8..eedf936 100644
--- a/docs/app-framework-development-guide.md
+++ b/docs/app-framework-development-guide.md
@@ -71,7 +71,7 @@ virtual void resourceOffers(SchedulerDriver* driver,
  * whatever reason an offer is never rescinded (e.g., dropped
  * message, failing over framework, etc.), a framework that attempts
  * to launch tasks using an invalid offer will receive TASK_LOST
- * status updats for those tasks (see Scheduler::resourceOffers).
+ * status updates for those tasks (see Scheduler::resourceOffers).
  */
 virtual void offerRescinded(SchedulerDriver* driver,
                             const OfferID& offerId) = 0;

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/docs/docker-containerizer.md
----------------------------------------------------------------------
diff --git a/docs/docker-containerizer.md b/docs/docker-containerizer.md
index 28b665f..89dfa0b 100644
--- a/docs/docker-containerizer.md
+++ b/docs/docker-containerizer.md
@@ -25,7 +25,7 @@ iptables -A INPUT -s 172.17.0.0/16 -i docker0 -p tcp -j ACCEPT
 
 ## How do I use the Docker Containerizer?
 
-TaskInfo before 0.20.0 used to only support either setting a CommandInfo that launches a task running the bash command, or a ExecutorInfo that launches a custom Executor
+TaskInfo before 0.20.0 used to only support either setting a CommandInfo that launches a task running the bash command, or an ExecutorInfo that launches a custom Executor
 that will launches the task.
 
 With 0.20.0 we added a ContainerInfo field to TaskInfo and ExecutorInfo that allows a Containerizer such as Docker to be configured to run the task or executor.
@@ -60,7 +60,7 @@ The containerizer also supports optional force pulling of the image. It is set d
 
 ## Private Docker repository
 
-To run a image from a private repository, one can include the uri pointing to a `.dockercfg` that contains login information. The `.dockercfg` file will be pulled into the sandbox the Docker Containerizer
+To run an image from a private repository, one can include the uri pointing to a `.dockercfg` that contains login information. The `.dockercfg` file will be pulled into the sandbox the Docker Containerizer
 set the HOME environment variable pointing to the sandbox so docker cli will automatically pick up the config file.
 
 ## CommandInfo to run Docker images

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/docs/networking-for-mesos-managed-containers.md
----------------------------------------------------------------------
diff --git a/docs/networking-for-mesos-managed-containers.md b/docs/networking-for-mesos-managed-containers.md
index 3b3fde4..f2fbea5 100644
--- a/docs/networking-for-mesos-managed-containers.md
+++ b/docs/networking-for-mesos-managed-containers.md
@@ -60,7 +60,7 @@ isolation using new data structures in the TaskInfo message.
     isolation
 
 * Cleanup Module:
-  * responsible for doing a cleanup (releasing IPs, etc.) during a Agent lost
+  * responsible for doing a cleanup (releasing IPs, etc.) during an Agent lost
     event, dormant otherwise
 
 ### Framework requests IP address for containers

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/docs/scheduler-http-api.md
----------------------------------------------------------------------
diff --git a/docs/scheduler-http-api.md b/docs/scheduler-http-api.md
index 4223a31..15ffb1e 100644
--- a/docs/scheduler-http-api.md
+++ b/docs/scheduler-http-api.md
@@ -375,7 +375,7 @@ The first event sent by the master when the scheduler sends a `SUBSCRIBE` reques
 
 
 ### OFFERS
-Sent by the master whenever there are new resources that can be offered to the framework. Each offer corresponds to a set of resources on a agent. Until the scheduler 'Accept's or 'Decline's an offer the resources are considered allocated to the scheduler, unless the offer is otherwise rescinded, e.g. due to a lost agent or `--offer_timeout`.
+Sent by the master whenever there are new resources that can be offered to the framework. Each offer corresponds to a set of resources on an agent. Until the scheduler 'Accept's or 'Decline's an offer the resources are considered allocated to the scheduler, unless the offer is otherwise rescinded, e.g. due to a lost agent or `--offer_timeout`.
 
 ```
 OFFERS Event (JSON)
@@ -452,7 +452,7 @@ MESSAGE Event (JSON)
 
 
 ### FAILURE
-Sent by the master when a agent is removed from the cluster (e.g., failed health checks) or when an executor is terminated. Note that, this event coincides with receipt of terminal `UPDATE` events for any active tasks belonging to the agent or executor and receipt of `RESCIND` events for any outstanding offers belonging to the agent. Note that there is no guaranteed order between the `FAILURE`, `UPDATE` and `RESCIND` events.
+Sent by the master when an agent is removed from the cluster (e.g., failed health checks) or when an executor is terminated. Note that, this event coincides with receipt of terminal `UPDATE` events for any active tasks belonging to the agent or executor and receipt of `RESCIND` events for any outstanding offers belonging to the agent. Note that there is no guaranteed order between the `FAILURE`, `UPDATE` and `RESCIND` events.
 
 ```
 FAILURE Event (JSON)

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/docs/upgrades.md
----------------------------------------------------------------------
diff --git a/docs/upgrades.md b/docs/upgrades.md
index 60cd08a..6880354 100644
--- a/docs/upgrades.md
+++ b/docs/upgrades.md
@@ -121,7 +121,7 @@ Please refer to the metrics/snapshot endpoint.
     }
 
 
-**NOTE** All Mesos arguments can now be passed using file:// to read them out of a file (either an absolute or relative path). The --credentials, --whitelist, and any flags that expect JSON backed arguments (such as --modules) behave as before, although support for just passing a absolute path for any JSON flags rather than file:// has been deprecated and will produce a warning (and the absolute path behavior will be removed in a future release).
+**NOTE** All Mesos arguments can now be passed using file:// to read them out of a file (either an absolute or relative path). The --credentials, --whitelist, and any flags that expect JSON backed arguments (such as --modules) behave as before, although support for just passing an absolute path for any JSON flags rather than file:// has been deprecated and will produce a warning (and the absolute path behavior will be removed in a future release).
 
 In order to upgrade a running cluster:
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/include/mesos/attributes.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/attributes.hpp b/include/mesos/attributes.hpp
index b894d3d..445d15e 100644
--- a/include/mesos/attributes.hpp
+++ b/include/mesos/attributes.hpp
@@ -67,7 +67,7 @@ public:
     return attributes.size();
   }
 
-  // Using this operator makes it easy to copy a attributes object into
+  // Using this operator makes it easy to copy an attributes object into
   // a protocol buffer field.
   operator const google::protobuf::RepeatedPtrField<Attribute>&() const
   {

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/include/mesos/v1/attributes.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/v1/attributes.hpp b/include/mesos/v1/attributes.hpp
index 911aef1..022bfde 100644
--- a/include/mesos/v1/attributes.hpp
+++ b/include/mesos/v1/attributes.hpp
@@ -70,7 +70,7 @@ public:
     return attributes.size();
   }
 
-  // Using this operator makes it easy to copy a attributes object into
+  // Using this operator makes it easy to copy an attributes object into
   // a protocol buffer field.
   operator const google::protobuf::RepeatedPtrField<Attribute>&() const
   {

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/include/mesos/v1/mesos.proto
----------------------------------------------------------------------
diff --git a/include/mesos/v1/mesos.proto b/include/mesos/v1/mesos.proto
index 4aed098..879107d 100644
--- a/include/mesos/v1/mesos.proto
+++ b/include/mesos/v1/mesos.proto
@@ -903,7 +903,7 @@ message Request {
 
 
 /**
- * Describes some resources available on a agent. An offer only
+ * Describes some resources available on an agent. An offer only
  * contains resources from a single agent.
  */
 message Offer {
@@ -981,7 +981,7 @@ message InverseOffer {
 
   // URL for reaching the agent running on the host.  This enables some
   // optimizations as described in MESOS-3012, such as allowing the
-  // scheduler driver to bypass the master and talk directly with a agent.
+  // scheduler driver to bypass the master and talk directly with an agent.
   optional URL url = 2;
 
   // The framework that should release its resources.
@@ -1357,7 +1357,7 @@ message Volume {
 
 /**
  * Describes a network request by framework as well as network resolution
- * provided by the the executor or Agent.
+ * provided by the executor or Agent.
  *
  * A framework may request the network isolator on the Agent to isolate the
  * container in a network namespace and create a virtual network interface.

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/include/mesos/v1/scheduler/scheduler.proto
----------------------------------------------------------------------
diff --git a/include/mesos/v1/scheduler/scheduler.proto b/include/mesos/v1/scheduler/scheduler.proto
index 6b40910..df09c19 100644
--- a/include/mesos/v1/scheduler/scheduler.proto
+++ b/include/mesos/v1/scheduler/scheduler.proto
@@ -104,7 +104,7 @@ message Event {
     required bytes data = 3;
   }
 
-  // Received when a agent is removed from the cluster (e.g., failed
+  // Received when an agent is removed from the cluster (e.g., failed
   // health checks) or when an executor is terminated. Note that, this
   // event coincides with receipt of terminal UPDATE events for any
   // active tasks belonging to the agent or executor and receipt of

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/examples/test_authorizer_module.cpp
----------------------------------------------------------------------
diff --git a/src/examples/test_authorizer_module.cpp b/src/examples/test_authorizer_module.cpp
index 116e6c1..95d77fb 100644
--- a/src/examples/test_authorizer_module.cpp
+++ b/src/examples/test_authorizer_module.cpp
@@ -36,7 +36,7 @@ static Authorizer* createAuthorizer(const Parameters& parameters)
 }
 
 
-// Declares a Authorizer module named
+// Declares an Authorizer module named
 // 'org_apache_mesos_TestLocalAuthorizer'.
 mesos::modules::Module<Authorizer> org_apache_mesos_TestLocalAuthorizer(
     MESOS_MODULE_API_VERSION,

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/java/src/org/apache/mesos/Scheduler.java
----------------------------------------------------------------------
diff --git a/src/java/src/org/apache/mesos/Scheduler.java b/src/java/src/org/apache/mesos/Scheduler.java
index fd1ad89..c7917d4 100644
--- a/src/java/src/org/apache/mesos/Scheduler.java
+++ b/src/java/src/org/apache/mesos/Scheduler.java
@@ -99,7 +99,7 @@ public interface Scheduler {
    * whatever reason an offer is never rescinded (e.g., dropped
    * message, failing over framework, etc.), a framework that attempts
    * to launch tasks using an invalid offer will receive TASK_LOST
-   * status updats for those tasks (see {@link #resourceOffers}).
+   * status updates for those tasks (see {@link #resourceOffers}).
    *
    * @param driver  The driver that was used to run this scheduler.
    * @param offerId The ID of the offer that was rescinded.

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/master/contender.cpp
----------------------------------------------------------------------
diff --git a/src/master/contender.cpp b/src/master/contender.cpp
index 750164e..9ad49ce 100644
--- a/src/master/contender.cpp
+++ b/src/master/contender.cpp
@@ -99,7 +99,7 @@ Try<MasterContender*> MasterContender::create(const Option<string>& _mechanism)
     // A "flags" endpoint where the framework can pass the command
     // line arguments and they will be parsed by <stout/flags> and the
     // needed flags extracted, and then change this interface to
-    // require final values from teh flags. This means that a
+    // require final values from the flags. This means that a
     // framework doesn't need to know how the flags are passed to
     // match mesos' command line arguments if it wants, but if it
     // needs to inspect/manipulate arguments, it can.

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/master/detector.cpp
----------------------------------------------------------------------
diff --git a/src/master/detector.cpp b/src/master/detector.cpp
index bfecce0..9274435 100644
--- a/src/master/detector.cpp
+++ b/src/master/detector.cpp
@@ -223,7 +223,7 @@ Try<MasterDetector*> MasterDetector::create(const Option<string>& _mechanism)
     // A "flags" endpoint where the framework can pass the command
     // line arguments and they will be parsed by <stout/flags> and the
     // needed flags extracted, and then change this interface to
-    // require final values from teh flags. This means that a
+    // require final values from the flags. This means that a
     // framework doesn't need to know how the flags are passed to
     // match mesos' command line arguments if it wants, but if it
     // needs to inspect/manipulate arguments, it can.

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/slave/containerizer/docker.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/docker.hpp b/src/slave/containerizer/docker.hpp
index 8927865..77a50d8 100644
--- a/src/slave/containerizer/docker.hpp
+++ b/src/slave/containerizer/docker.hpp
@@ -457,7 +457,7 @@ private:
     // on destroy.
     Option<pid_t> executorPid;
 
-    // Marks if this container launches a executor in a docker
+    // Marks if this container launches an executor in a docker
     // container.
     bool launchesExecutorContainer;
   };

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/tests/active_user_test_helper.cpp
----------------------------------------------------------------------
diff --git a/src/tests/active_user_test_helper.cpp b/src/tests/active_user_test_helper.cpp
index d5e3924..54e8668 100644
--- a/src/tests/active_user_test_helper.cpp
+++ b/src/tests/active_user_test_helper.cpp
@@ -19,7 +19,7 @@
 
 #include <stout/os.hpp>
 
-// This helper program takes a an expected user.
+// This helper program takes an expected user.
 // Returns 0 if the current username equals the expected username.
 // Returns 1 otherwise.
 int main(int argc, char **argv) {

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/tests/containerizer/docker_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer/docker_tests.cpp b/src/tests/containerizer/docker_tests.cpp
index 72961af..a65d552 100644
--- a/src/tests/containerizer/docker_tests.cpp
+++ b/src/tests/containerizer/docker_tests.cpp
@@ -414,7 +414,7 @@ TEST_F(DockerTest, ROOT_DOCKER_MountRelative)
 }
 
 
-// This test verifies mounting in a absolute path when running a
+// This test verifies mounting in an absolute path when running a
 // docker container works.
 TEST_F(DockerTest, ROOT_DOCKER_MountAbsolute)
 {

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/tests/executor_http_api_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/executor_http_api_tests.cpp b/src/tests/executor_http_api_tests.cpp
index 8d86df5..952aacb 100644
--- a/src/tests/executor_http_api_tests.cpp
+++ b/src/tests/executor_http_api_tests.cpp
@@ -318,7 +318,7 @@ TEST_F(ExecutorHttpApiTest, GetRequest)
 }
 
 
-// This test sends in a Accept:*/* header meaning it would
+// This test sends in an Accept:*/* header meaning it would
 // accept any media type in the response. We expect the
 // default "application/json" media type.
 TEST_P(ExecutorHttpApiTest, DefaultAccept)

http://git-wip-us.apache.org/repos/asf/mesos/blob/80c123ec/src/tests/state_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/state_tests.cpp b/src/tests/state_tests.cpp
index 685f346..0b0bc9c 100644
--- a/src/tests/state_tests.cpp
+++ b/src/tests/state_tests.cpp
@@ -662,7 +662,7 @@ TEST_F(LogStateTest, Diff)
 
   AWAIT_READY(entries);
 
-  // Convert each Log::Entry to a Operation.
+  // Convert each Log::Entry to an Operation.
   vector<Operation> operations;
 
   foreach (const Log::Entry& entry, entries.get()) {


[3/3] mesos git commit: Stout: Fixed typo in warning message.

Posted by jo...@apache.org.
Stout: Fixed typo in warning message.

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


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

Branch: refs/heads/master
Commit: 62651a43ad113d78e6c4de6229baf66209af5fcf
Parents: abe0bf4
Author: Neil Conway <ne...@gmail.com>
Authored: Mon Jan 11 15:50:38 2016 -0800
Committer: Joris Van Remoortere <jo...@gmail.com>
Committed: Mon Jan 11 15:52:35 2016 -0800

----------------------------------------------------------------------
 3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/62651a43/3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp b/3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp
index 82596ed..295eac7 100644
--- a/3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp
+++ b/3rdparty/libprocess/3rdparty/stout/include/stout/flags/parse.hpp
@@ -83,7 +83,7 @@ inline Try<JSON::Object> parse(const std::string& value)
   // 'fetch' mechanism for flags that first fetches the data from URIs
   // such as 'file://').
   if (strings::startsWith(value, "/")) {
-    LOG(WARNING) << "Specifying a absolute filename to read a command line "
+    LOG(WARNING) << "Specifying an absolute filename to read a command line "
                     "option out of without using 'file:// is deprecated and "
                     "will be removed in a future release. Simply adding "
                     "'file://' to the beginning of the path should eliminate "


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

Posted by jo...@apache.org.
Libprocess: Fixed typos in comments.

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


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

Branch: refs/heads/master
Commit: fee4f2b933cc9ba893bf253692c648ed015e412a
Parents: 62651a4
Author: Neil Conway <ne...@gmail.com>
Authored: Mon Jan 11 15:50:29 2016 -0800
Committer: Joris Van Remoortere <jo...@gmail.com>
Committed: Mon Jan 11 15:52:35 2016 -0800

----------------------------------------------------------------------
 3rdparty/libprocess/include/process/executor.hpp | 2 +-
 3rdparty/libprocess/include/process/http.hpp     | 2 +-
 3rdparty/libprocess/src/http.cpp                 | 2 +-
 3rdparty/libprocess/src/process.cpp              | 2 +-
 3rdparty/libprocess/src/tests/http_tests.cpp     | 2 +-
 5 files changed, 5 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/fee4f2b9/3rdparty/libprocess/include/process/executor.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/executor.hpp b/3rdparty/libprocess/include/process/executor.hpp
index 9f5c206..fbf9251 100644
--- a/3rdparty/libprocess/include/process/executor.hpp
+++ b/3rdparty/libprocess/include/process/executor.hpp
@@ -47,7 +47,7 @@ public:
     // TODO(benh): Note that this doesn't wait because that could
     // cause a deadlock ... thus, the semantics here are that no more
     // dispatches will occur after this function returns but one may
-    // be occuring concurrently.
+    // be occurring concurrently.
   }
 
   template <typename F>

http://git-wip-us.apache.org/repos/asf/mesos/blob/fee4f2b9/3rdparty/libprocess/include/process/http.hpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/include/process/http.hpp b/3rdparty/libprocess/include/process/http.hpp
index ed708fe..d0f820e 100644
--- a/3rdparty/libprocess/include/process/http.hpp
+++ b/3rdparty/libprocess/include/process/http.hpp
@@ -267,7 +267,7 @@ struct Request
 // processes.
 //
 // Much like unix pipes, data is read until end-of-file is
-// encountered; this occurs when the the write-end of the pipe is
+// encountered; this occurs when the write-end of the pipe is
 // closed and there is no outstanding data left to read.
 //
 // Unlike unix pipes, if the read-end of the pipe is closed before

http://git-wip-us.apache.org/repos/asf/mesos/blob/fee4f2b9/3rdparty/libprocess/src/http.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/http.cpp b/3rdparty/libprocess/src/http.cpp
index 06231d9..aabfd5d 100644
--- a/3rdparty/libprocess/src/http.cpp
+++ b/3rdparty/libprocess/src/http.cpp
@@ -1222,7 +1222,7 @@ Future<Response> request(const Request& request, bool streamedResponse)
   // This is a one time request which will close the connection when
   // the response is received. Since 'Connection' is reference-counted,
   // we must keep a copy around until the disconnection occurs. Note
-  // that in order to avoid a deadlock (Connection destruction occuring
+  // that in order to avoid a deadlock (Connection destruction occurring
   // from the ConnectionProcess execution context), we use 'async'.
   return http::connect(request.url)
     .then([=](Connection connection) {

http://git-wip-us.apache.org/repos/asf/mesos/blob/fee4f2b9/3rdparty/libprocess/src/process.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/process.cpp b/3rdparty/libprocess/src/process.cpp
index 7fd278a..d8a74d7 100644
--- a/3rdparty/libprocess/src/process.cpp
+++ b/3rdparty/libprocess/src/process.cpp
@@ -1821,7 +1821,7 @@ Encoder* SocketManager::next(int s)
 
   synchronized (mutex) {
     // We cannot assume 'sockets.count(s) > 0' here because it's
-    // possible that 's' has been removed with a a call to
+    // possible that 's' has been removed with a call to
     // SocketManager::close. For example, it could be the case that a
     // socket has gone to CLOSE_WAIT and the call to read in
     // io::read returned 0 causing SocketManager::close to get

http://git-wip-us.apache.org/repos/asf/mesos/blob/fee4f2b9/3rdparty/libprocess/src/tests/http_tests.cpp
----------------------------------------------------------------------
diff --git a/3rdparty/libprocess/src/tests/http_tests.cpp b/3rdparty/libprocess/src/tests/http_tests.cpp
index e5999d8..c23d0bf 100644
--- a/3rdparty/libprocess/src/tests/http_tests.cpp
+++ b/3rdparty/libprocess/src/tests/http_tests.cpp
@@ -980,7 +980,7 @@ TEST(HTTPConnectionTest, ReferenceCounting)
       http.process->self().address.port,
       http.process->self().id + "/get");
 
-  // Capture the connection as a Owned in order to test that
+  // Capture the connection as an Owned in order to test that
   // when the last copy of the Connection is destructed, a
   // disconnection occurs.
   auto connect = Owned<Future<http::Connection>>(