You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mesos.apache.org by nn...@apache.org on 2015/02/05 23:28:54 UTC

[1/4] mesos git commit: Internal deprecation 1: Removed mesos::internal namespace.

Repository: mesos
Updated Branches:
  refs/heads/master 17285e778 -> 830f4b3a9


http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/flags.hpp
----------------------------------------------------------------------
diff --git a/src/tests/flags.hpp b/src/tests/flags.hpp
index 0d3db6c..0be991f 100644
--- a/src/tests/flags.hpp
+++ b/src/tests/flags.hpp
@@ -32,7 +32,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 class Flags : public logging::Flags
@@ -158,7 +157,6 @@ public:
 extern Flags flags;
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/fs_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/fs_tests.cpp b/src/tests/fs_tests.cpp
index 946242d..0ea286b 100644
--- a/src/tests/fs_tests.cpp
+++ b/src/tests/fs_tests.cpp
@@ -30,7 +30,6 @@
 
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using fs::MountTable;
 using fs::FileSystemTable;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/gc_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/gc_tests.cpp b/src/tests/gc_tests.cpp
index 454f097..2cf7d16 100644
--- a/src/tests/gc_tests.cpp
+++ b/src/tests/gc_tests.cpp
@@ -58,14 +58,13 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::GarbageCollector;
-using mesos::internal::slave::GarbageCollectorProcess;
-using mesos::internal::slave::Slave;
+using mesos::slave::GarbageCollector;
+using mesos::slave::GarbageCollectorProcess;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/group_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/group_tests.cpp b/src/tests/group_tests.cpp
index 144ba82..5344087 100644
--- a/src/tests/group_tests.cpp
+++ b/src/tests/group_tests.cpp
@@ -33,8 +33,8 @@
 #include "zookeeper/authentication.hpp"
 #include "zookeeper/group.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos;
+using namespace mesos::tests;
 
 using zookeeper::Group;
 using zookeeper::GroupProcess;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/health_check_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/health_check_tests.cpp b/src/tests/health_check_tests.cpp
index 7278f07..7fcb231 100644
--- a/src/tests/health_check_tests.cpp
+++ b/src/tests/health_check_tests.cpp
@@ -33,16 +33,15 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::MesosContainerizer;
-using mesos::internal::slave::MesosContainerizerProcess;
-using mesos::internal::slave::Slave;
+using mesos::slave::Containerizer;
+using mesos::slave::Fetcher;
+using mesos::slave::MesosContainerizer;
+using mesos::slave::MesosContainerizerProcess;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/hierarchical_allocator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/hierarchical_allocator_tests.cpp b/src/tests/hierarchical_allocator_tests.cpp
index f44d9e9..df844b5 100644
--- a/src/tests/hierarchical_allocator_tests.cpp
+++ b/src/tests/hierarchical_allocator_tests.cpp
@@ -39,14 +39,13 @@
 #include "master/hierarchical_allocator_process.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
-using mesos::internal::master::MIN_CPUS;
-using mesos::internal::master::MIN_MEM;
+using mesos::master::MIN_CPUS;
+using mesos::master::MIN_MEM;
 
-using mesos::internal::master::allocator::Allocator;
-using mesos::internal::master::allocator::AllocatorProcess;
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::Allocator;
+using mesos::master::allocator::AllocatorProcess;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/hook_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/hook_tests.cpp b/src/tests/hook_tests.cpp
index 44f73ef..dc6d289 100644
--- a/src/tests/hook_tests.cpp
+++ b/src/tests/hook_tests.cpp
@@ -40,12 +40,11 @@
 using std::string;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 using namespace mesos::modules;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/isolator.hpp
----------------------------------------------------------------------
diff --git a/src/tests/isolator.hpp b/src/tests/isolator.hpp
index 2c3a694..7c40f3c 100644
--- a/src/tests/isolator.hpp
+++ b/src/tests/isolator.hpp
@@ -24,7 +24,6 @@
 #include "slave/containerizer/isolator.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 
@@ -93,7 +92,6 @@ private:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TEST_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/isolator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/isolator_tests.cpp b/src/tests/isolator_tests.cpp
index 1f1c26d..093b9fd 100644
--- a/src/tests/isolator_tests.cpp
+++ b/src/tests/isolator_tests.cpp
@@ -72,30 +72,30 @@
 
 using namespace mesos;
 
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos;
+using namespace mesos::tests;
 
 using namespace process;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 #ifdef __linux__
-using mesos::internal::slave::CgroupsCpushareIsolatorProcess;
-using mesos::internal::slave::CgroupsMemIsolatorProcess;
-using mesos::internal::slave::CgroupsPerfEventIsolatorProcess;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::SharedFilesystemIsolatorProcess;
+using mesos::slave::CgroupsCpushareIsolatorProcess;
+using mesos::slave::CgroupsMemIsolatorProcess;
+using mesos::slave::CgroupsPerfEventIsolatorProcess;
+using mesos::slave::Fetcher;
+using mesos::slave::SharedFilesystemIsolatorProcess;
 #endif // __linux__
-using mesos::internal::slave::Isolator;
-using mesos::internal::slave::IsolatorProcess;
-using mesos::internal::slave::Launcher;
-using mesos::internal::slave::MesosContainerizer;
-using mesos::internal::slave::Slave;
+using mesos::slave::Isolator;
+using mesos::slave::IsolatorProcess;
+using mesos::slave::Launcher;
+using mesos::slave::MesosContainerizer;
+using mesos::slave::Slave;
 #ifdef __linux__
-using mesos::internal::slave::LinuxLauncher;
+using mesos::slave::LinuxLauncher;
 #endif // __linux__
-using mesos::internal::slave::PosixLauncher;
-using mesos::internal::slave::PosixCpuIsolatorProcess;
-using mesos::internal::slave::PosixMemIsolatorProcess;
+using mesos::slave::PosixLauncher;
+using mesos::slave::PosixCpuIsolatorProcess;
+using mesos::slave::PosixMemIsolatorProcess;
 
 
 using std::ostringstream;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/log_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/log_tests.cpp b/src/tests/log_tests.cpp
index 0088706..8cbc4df 100644
--- a/src/tests/log_tests.cpp
+++ b/src/tests/log_tests.cpp
@@ -60,9 +60,8 @@
 #endif
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::log;
-using namespace mesos::internal::tests;
+using namespace mesos::log;
+using namespace mesos::tests;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/logging_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/logging_tests.cpp b/src/tests/logging_tests.cpp
index 22a785e..dcfbe5f 100644
--- a/src/tests/logging_tests.cpp
+++ b/src/tests/logging_tests.cpp
@@ -26,7 +26,7 @@
 
 #include "logging/logging.hpp"
 
-using namespace mesos::internal;
+using namespace mesos;
 
 using process::http::BadRequest;
 using process::http::OK;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/main.cpp
----------------------------------------------------------------------
diff --git a/src/tests/main.cpp b/src/tests/main.cpp
index e3fff5d..0ab6be5 100644
--- a/src/tests/main.cpp
+++ b/src/tests/main.cpp
@@ -39,8 +39,8 @@
 #include "tests/flags.hpp"
 #include "tests/module.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos;
+using namespace mesos::tests;
 
 using std::cerr;
 using std::endl;
@@ -60,7 +60,7 @@ int main(int argc, char** argv)
 {
   GOOGLE_PROTOBUF_VERIFY_VERSION;
 
-  using mesos::internal::tests::flags; // Needed to disabmiguate.
+  using mesos::tests::flags; // Needed to disabmiguate.
 
   bool help;
   flags.add(&help,
@@ -119,7 +119,7 @@ int main(int argc, char** argv)
 
   // Instantiate our environment. Note that it will be managed by
   // gtest after we add it via testing::AddGlobalTestEnvironment.
-  environment = new Environment(flags);
+  environment = new tests::Environment(flags);
 
   testing::AddGlobalTestEnvironment(environment);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_allocator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_allocator_tests.cpp b/src/tests/master_allocator_tests.cpp
index 018a6cc..1eebefd 100644
--- a/src/tests/master_allocator_tests.cpp
+++ b/src/tests/master_allocator_tests.cpp
@@ -43,16 +43,15 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::allocator::Allocator;
-using mesos::internal::master::allocator::AllocatorProcess;
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::Allocator;
+using mesos::master::allocator::AllocatorProcess;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;
@@ -1124,7 +1123,7 @@ TYPED_TEST(MasterAllocatorTest, Whitelist)
 
   ASSERT_SOME(os::write(path, strings::join("\n", hosts)));
 
-  Clock::advance(mesos::internal::master::WHITELIST_WATCH_INTERVAL);
+  Clock::advance(mesos::master::WHITELIST_WATCH_INTERVAL);
 
   // Make sure the allocator has been given the updated whitelist.
   AWAIT_READY(updateWhitelist2);

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_authorization_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_authorization_tests.cpp b/src/tests/master_authorization_tests.cpp
index 20adaa9..6fd0efa 100644
--- a/src/tests/master_authorization_tests.cpp
+++ b/src/tests/master_authorization_tests.cpp
@@ -41,14 +41,13 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::master::allocator::AllocatorProcess;
+using mesos::master::allocator::AllocatorProcess;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_contender_detector_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_contender_detector_tests.cpp b/src/tests/master_contender_detector_tests.cpp
index d847a30..e94cd79 100644
--- a/src/tests/master_contender_detector_tests.cpp
+++ b/src/tests/master_contender_detector_tests.cpp
@@ -55,14 +55,13 @@
 #endif
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace zookeeper;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;
@@ -135,7 +134,7 @@ TEST(BasicMasterContenderDetectorTest, Contender)
 
   MasterContender* contender = new StandaloneMasterContender();
 
-  contender->initialize(internal::protobuf::createMasterInfo(master));
+  contender->initialize(mesos::protobuf::createMasterInfo(master));
 
   Future<Future<Nothing> > contended = contender->contend();
   AWAIT_READY(contended);
@@ -201,7 +200,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterContender)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo master = internal::protobuf::createMasterInfo(pid);
+  MasterInfo master = mesos::protobuf::createMasterInfo(pid);
 
   contender->initialize(master);
   Future<Future<Nothing> > contended = contender->contend();
@@ -259,7 +258,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, ContenderPendingElection)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo master = internal::protobuf::createMasterInfo(pid);
+  MasterInfo master = mesos::protobuf::createMasterInfo(pid);
 
   contender.initialize(master);
 
@@ -313,7 +312,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterContenders)
   PID<Master> pid1;
   pid1.node.ip = 10000000;
   pid1.node.port = 10000;
-  MasterInfo master1 = internal::protobuf::createMasterInfo(pid1);
+  MasterInfo master1 = mesos::protobuf::createMasterInfo(pid1);
 
   contender1->initialize(master1);
 
@@ -331,7 +330,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterContenders)
   PID<Master> pid2;
   pid2.node.ip = 10000001;
   pid2.node.port = 10001;
-  MasterInfo master2 = internal::protobuf::createMasterInfo(pid2);
+  MasterInfo master2 = mesos::protobuf::createMasterInfo(pid2);
 
   contender2.initialize(master2);
 
@@ -370,7 +369,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, NonRetryableFrrors)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo master = internal::protobuf::createMasterInfo(pid);
+  MasterInfo master = mesos::protobuf::createMasterInfo(pid);
 
   // group2's password is wrong and operations on it will fail.
   Owned<zookeeper::Group> group2(new Group(
@@ -434,7 +433,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, ContenderDetectorShutdownNetwork)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo master = internal::protobuf::createMasterInfo(pid);
+  MasterInfo master = mesos::protobuf::createMasterInfo(pid);
 
   contender.initialize(master);
 
@@ -510,7 +509,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterDetectorTimedoutSession)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo leader = internal::protobuf::createMasterInfo(pid);
+  MasterInfo leader = mesos::protobuf::createMasterInfo(pid);
 
   leaderContender.initialize(leader);
 
@@ -531,7 +530,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterDetectorTimedoutSession)
   PID<Master> pid2;
   pid2.node.ip = 10000001;
   pid2.node.port = 10001;
-  MasterInfo follower = internal::protobuf::createMasterInfo(pid2);
+  MasterInfo follower = mesos::protobuf::createMasterInfo(pid2);
 
   followerContender.initialize(follower);
 
@@ -620,7 +619,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest,
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo leader = internal::protobuf::createMasterInfo(pid);
+  MasterInfo leader = mesos::protobuf::createMasterInfo(pid);
 
   // Create the group instance so we can expire its session.
   Owned<zookeeper::Group> group(
@@ -649,7 +648,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest,
   PID<Master> pid2;
   pid2.node.ip = 10000001;
   pid2.node.port = 10001;
-  MasterInfo follower = internal::protobuf::createMasterInfo(pid2);
+  MasterInfo follower = mesos::protobuf::createMasterInfo(pid2);
 
   ZooKeeperMasterDetector followerDetector(url.get());
   ZooKeeperMasterContender followerContender(url.get());
@@ -696,7 +695,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest, MasterDetectorExpireSlaveZKSession)
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo master = internal::protobuf::createMasterInfo(pid);
+  MasterInfo master = mesos::protobuf::createMasterInfo(pid);
 
   ZooKeeperMasterContender masterContender(url.get());
   masterContender.initialize(master);
@@ -757,7 +756,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest,
   PID<Master> pid;
   pid.node.ip = 10000000;
   pid.node.port = 10000;
-  MasterInfo leader = internal::protobuf::createMasterInfo(pid);
+  MasterInfo leader = mesos::protobuf::createMasterInfo(pid);
 
   leaderContender.initialize(leader);
 
@@ -777,7 +776,7 @@ TEST_F(ZooKeeperMasterContenderDetectorTest,
   PID<Master> pid2;
   pid2.node.ip = 10000001;
   pid2.node.port = 10001;
-  MasterInfo follower = internal::protobuf::createMasterInfo(pid2);
+  MasterInfo follower = mesos::protobuf::createMasterInfo(pid2);
 
   followerContender.initialize(follower);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_slave_reconciliation_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_slave_reconciliation_tests.cpp b/src/tests/master_slave_reconciliation_tests.cpp
index 04806ed..0974285 100644
--- a/src/tests/master_slave_reconciliation_tests.cpp
+++ b/src/tests/master_slave_reconciliation_tests.cpp
@@ -41,13 +41,12 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::protobuf;
-using namespace mesos::internal::tests;
+using namespace mesos::protobuf;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_tests.cpp b/src/tests/master_tests.cpp
index e604188..62ba35b 100644
--- a/src/tests/master_tests.cpp
+++ b/src/tests/master_tests.cpp
@@ -57,18 +57,17 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::master::allocator::AllocatorProcess;
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::AllocatorProcess;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
-using mesos::internal::slave::GarbageCollectorProcess;
-using mesos::internal::slave::Slave;
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::MesosContainerizerProcess;
+using mesos::slave::GarbageCollectorProcess;
+using mesos::slave::Slave;
+using mesos::slave::Containerizer;
+using mesos::slave::MesosContainerizerProcess;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/master_validation_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/master_validation_tests.cpp b/src/tests/master_validation_tests.cpp
index 81c635f..e2b6426 100644
--- a/src/tests/master_validation_tests.cpp
+++ b/src/tests/master_validation_tests.cpp
@@ -30,8 +30,8 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal::tests;
-using namespace mesos::internal::master::validation;
+using namespace mesos::tests;
+using namespace mesos::master::validation;
 
 using google::protobuf::RepeatedPtrField;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/mesos.cpp
----------------------------------------------------------------------
diff --git a/src/tests/mesos.cpp b/src/tests/mesos.cpp
index 5ed4df5..21a4053 100644
--- a/src/tests/mesos.cpp
+++ b/src/tests/mesos.cpp
@@ -58,7 +58,6 @@ using namespace routing;
 #endif
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 #ifdef MESOS_HAS_JAVA
@@ -585,5 +584,4 @@ void ContainerizerTest<slave::MesosContainerizer>::TearDown()
 #endif // __linux__
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/mesos.hpp
----------------------------------------------------------------------
diff --git a/src/tests/mesos.hpp b/src/tests/mesos.hpp
index 17c2d8f..83a3699 100644
--- a/src/tests/mesos.hpp
+++ b/src/tests/mesos.hpp
@@ -68,7 +68,6 @@ using ::testing::DoDefault;
 using ::testing::Return;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Forward declarations.
@@ -1122,7 +1121,6 @@ void ExpectNoFutureProtobufs(T t, From from, To to)
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_MESOS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/metrics_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/metrics_tests.cpp b/src/tests/metrics_tests.cpp
index 7512b90..751f82a 100644
--- a/src/tests/metrics_tests.cpp
+++ b/src/tests/metrics_tests.cpp
@@ -29,12 +29,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Slave;
 
-class MetricsTest : public mesos::internal::tests::MesosTest {};
+class MetricsTest : public mesos::tests::MesosTest {};
 
 TEST_F(MetricsTest, Master)
 {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/module.cpp
----------------------------------------------------------------------
diff --git a/src/tests/module.cpp b/src/tests/module.cpp
index e6dbf94..3c9bab7 100644
--- a/src/tests/module.cpp
+++ b/src/tests/module.cpp
@@ -31,8 +31,7 @@
 using std::string;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 using namespace mesos::modules;
 
 static hashmap<ModuleID, string> moduleNames;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/module.hpp
----------------------------------------------------------------------
diff --git a/src/tests/module.hpp b/src/tests/module.hpp
index 21e8fc4..776a426 100644
--- a/src/tests/module.hpp
+++ b/src/tests/module.hpp
@@ -30,7 +30,6 @@
 #include "tests/mesos.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // The ModuleID is used by typed tests to specify the specific module
@@ -74,7 +73,6 @@ public:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_MODULE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/module_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/module_tests.cpp b/src/tests/module_tests.cpp
index df30e16..2e113be 100644
--- a/src/tests/module_tests.cpp
+++ b/src/tests/module_tests.cpp
@@ -33,9 +33,8 @@
 using std::string;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 using namespace mesos::modules;
 
 const char* DEFAULT_MODULE_LIBRARY_NAME = "examplemodule";

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/monitor_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/monitor_tests.cpp b/src/tests/monitor_tests.cpp
index 3b02619..9946741 100644
--- a/src/tests/monitor_tests.cpp
+++ b/src/tests/monitor_tests.cpp
@@ -39,8 +39,7 @@
 #include "tests/containerizer.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/ns_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/ns_tests.cpp b/src/tests/ns_tests.cpp
index 046ea26..b11a216 100644
--- a/src/tests/ns_tests.cpp
+++ b/src/tests/ns_tests.cpp
@@ -41,7 +41,7 @@
 #include "tests/flags.hpp"
 
 
-using namespace mesos::internal;
+using namespace mesos;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/partition_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/partition_tests.cpp b/src/tests/partition_tests.cpp
index b3af282..bd7940d 100644
--- a/src/tests/partition_tests.cpp
+++ b/src/tests/partition_tests.cpp
@@ -38,14 +38,13 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::master::allocator::AllocatorProcess;
+using mesos::master::allocator::AllocatorProcess;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/paths_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/paths_tests.cpp b/src/tests/paths_tests.cpp
index 9b71796..07e8af5 100644
--- a/src/tests/paths_tests.cpp
+++ b/src/tests/paths_tests.cpp
@@ -32,7 +32,6 @@
 #include "slave/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 namespace paths {
 
@@ -217,5 +216,4 @@ TEST_F(PathsTest, PersistentVolume)
 
 } // namespace paths {
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/port_mapping_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/port_mapping_tests.cpp b/src/tests/port_mapping_tests.cpp
index 18d58ff..462e49a 100644
--- a/src/tests/port_mapping_tests.cpp
+++ b/src/tests/port_mapping_tests.cpp
@@ -61,10 +61,8 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
 using namespace process;
 
@@ -72,13 +70,13 @@ using namespace routing;
 using namespace routing::filter;
 using namespace routing::queueing;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Launcher;
-using mesos::internal::slave::LinuxLauncher;
-using mesos::internal::slave::MesosContainerizer;
-using mesos::internal::slave::MesosContainerizerLaunch;
-using mesos::internal::slave::PortMappingIsolatorProcess;
+using mesos::slave::Launcher;
+using mesos::slave::LinuxLauncher;
+using mesos::slave::MesosContainerizer;
+using mesos::slave::MesosContainerizerLaunch;
+using mesos::slave::PortMappingIsolatorProcess;
 
 using std::list;
 using std::ostringstream;
@@ -132,7 +130,7 @@ static void cleanup(const string& eth0, const string& lo)
 
     // NOTE: Here, we ignore the unmount errors because previous tests
     // may have created the file and died before mounting.
-    mesos::internal::fs::unmount(target, MNT_DETACH);
+    mesos::fs::unmount(target, MNT_DETACH);
 
     // Use best effort to remove the bind mount file, but it is okay
     // the file can't be removed at this point.

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/protobuf_io_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/protobuf_io_tests.cpp b/src/tests/protobuf_io_tests.cpp
index d5d788c..a54f20d 100644
--- a/src/tests/protobuf_io_tests.cpp
+++ b/src/tests/protobuf_io_tests.cpp
@@ -33,8 +33,7 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/rate_limiting_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/rate_limiting_tests.cpp b/src/tests/rate_limiting_tests.cpp
index 7f5ca25..34c2267 100644
--- a/src/tests/rate_limiting_tests.cpp
+++ b/src/tests/rate_limiting_tests.cpp
@@ -32,12 +32,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::master::allocator::AllocatorProcess;
+using mesos::master::allocator::AllocatorProcess;
 
 using process::metrics::internal::MetricsProcess;
 
@@ -52,7 +51,6 @@ using testing::Eq;
 using testing::Return;
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // Query Mesos metrics snapshot endpoint and return a JSON::Object
@@ -1115,5 +1113,4 @@ TEST_F(RateLimitingTest, CapacityReached)
 }
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/reconciliation_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/reconciliation_tests.cpp b/src/tests/reconciliation_tests.cpp
index c21f4cb..4c97341 100644
--- a/src/tests/reconciliation_tests.cpp
+++ b/src/tests/reconciliation_tests.cpp
@@ -44,12 +44,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/registrar_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/registrar_tests.cpp b/src/tests/registrar_tests.cpp
index 6bfb679..3d71233 100644
--- a/src/tests/registrar_tests.cpp
+++ b/src/tests/registrar_tests.cpp
@@ -52,18 +52,17 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using namespace process;
 
-using log::Log;
-using log::Replica;
+using mesos::log::Log;
+using mesos::log::Replica;
 
-using state::Entry;
-using state::LogStorage;
-using state::Storage;
+using mesos::state::Entry;
+using mesos::state::LogStorage;
+using mesos::state::Storage;
 
-using state::protobuf::State;
+using mesos::state::protobuf::State;
 
 using std::map;
 using std::set;
@@ -75,12 +74,11 @@ using testing::DoAll;
 using testing::Eq;
 using testing::Return;
 
-using mesos::internal::tests::TemporaryDirectoryTest;
+using mesos::tests::TemporaryDirectoryTest;
 
 using ::testing::WithParamInterface;
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // TODO(xujyan): This class copies code from LogStateTest. It would
@@ -528,5 +526,4 @@ TEST_P(Registrar_BENCHMARK_Test, performance)
 }
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/registrar_zookeeper_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/registrar_zookeeper_tests.cpp b/src/tests/registrar_zookeeper_tests.cpp
index 376ac1e..30d3cd8 100644
--- a/src/tests/registrar_zookeeper_tests.cpp
+++ b/src/tests/registrar_zookeeper_tests.cpp
@@ -35,12 +35,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/repair_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/repair_tests.cpp b/src/tests/repair_tests.cpp
index 5235058..734d3b7 100644
--- a/src/tests/repair_tests.cpp
+++ b/src/tests/repair_tests.cpp
@@ -31,10 +31,9 @@
 
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/resource_offers_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/resource_offers_tests.cpp b/src/tests/resource_offers_tests.cpp
index 3e529ba..b371153 100644
--- a/src/tests/resource_offers_tests.cpp
+++ b/src/tests/resource_offers_tests.cpp
@@ -34,14 +34,13 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/resources_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/resources_tests.cpp b/src/tests/resources_tests.cpp
index 4744e87..3f98782 100644
--- a/src/tests/resources_tests.cpp
+++ b/src/tests/resources_tests.cpp
@@ -29,9 +29,8 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::master;
-using namespace mesos::internal::tests;
+using namespace mesos::master;
+using namespace mesos::tests;
 
 using std::ostringstream;
 using std::pair;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/scheduler_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/scheduler_tests.cpp b/src/tests/scheduler_tests.cpp
index e998217..080ec72 100644
--- a/src/tests/scheduler_tests.cpp
+++ b/src/tests/scheduler_tests.cpp
@@ -47,13 +47,12 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Slave;
+using mesos::slave::Containerizer;
+using mesos::slave::Slave;
 
 using mesos::scheduler::Call;
 using mesos::scheduler::Event;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/script.cpp
----------------------------------------------------------------------
diff --git a/src/tests/script.cpp b/src/tests/script.cpp
index 515e314..ddbec76 100644
--- a/src/tests/script.cpp
+++ b/src/tests/script.cpp
@@ -43,7 +43,6 @@
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 void execute(const string& script)
@@ -163,5 +162,4 @@ void execute(const string& script)
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/script.hpp
----------------------------------------------------------------------
diff --git a/src/tests/script.hpp b/src/tests/script.hpp
index f0c71e1..d25b1e2 100644
--- a/src/tests/script.hpp
+++ b/src/tests/script.hpp
@@ -22,14 +22,12 @@
 #include <gtest/gtest.h>
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Helper used by TEST_SCRIPT to execute the script.
 void execute(const std::string& script);
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 
@@ -39,7 +37,7 @@ void execute(const std::string& script);
 // script returns 0.
 #define TEST_SCRIPT(test_case_name, test_name, script)      \
   TEST(test_case_name, test_name) {                         \
-    mesos::internal::tests::execute(script);                \
+    mesos::tests::execute(script);                \
   }
 
 #endif // __TESTS_SCRIPT_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/shutdown_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/shutdown_tests.cpp b/src/tests/shutdown_tests.cpp
index bb48ee0..9017517 100644
--- a/src/tests/shutdown_tests.cpp
+++ b/src/tests/shutdown_tests.cpp
@@ -41,12 +41,11 @@
 using std::string;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/slave_recovery_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/slave_recovery_tests.cpp b/src/tests/slave_recovery_tests.cpp
index 7e2e63d..bd2bdef 100644
--- a/src/tests/slave_recovery_tests.cpp
+++ b/src/tests/slave_recovery_tests.cpp
@@ -59,22 +59,20 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
 using namespace process;
 
 using google::protobuf::RepeatedPtrField;
 
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::GarbageCollectorProcess;
+using mesos::slave::Containerizer;
+using mesos::slave::Fetcher;
+using mesos::slave::GarbageCollectorProcess;
 
 using std::map;
 using std::string;
@@ -288,7 +286,7 @@ TYPED_TEST(SlaveRecoveryTest, RecoverSlaveState)
                 .runs[containerId.get()]
                 .tasks.contains(task.task_id()));
 
-  const Task& t = mesos::internal::protobuf::createTask(
+  const Task& t = mesos::protobuf::createTask(
       task, TASK_STAGING, frameworkId);
 
   ASSERT_SOME_EQ(

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/slave_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/slave_tests.cpp b/src/tests/slave_tests.cpp
index 956ce64..68a6498 100644
--- a/src/tests/slave_tests.cpp
+++ b/src/tests/slave_tests.cpp
@@ -61,19 +61,18 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::GarbageCollectorProcess;
-using mesos::internal::slave::MesosContainerizer;
-using mesos::internal::slave::MesosContainerizerProcess;
-using mesos::internal::slave::Slave;
+using mesos::slave::Containerizer;
+using mesos::slave::Fetcher;
+using mesos::slave::GarbageCollectorProcess;
+using mesos::slave::MesosContainerizer;
+using mesos::slave::MesosContainerizerProcess;
+using mesos::slave::Slave;
 
 using std::map;
 using std::string;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/sorter_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/sorter_tests.cpp b/src/tests/sorter_tests.cpp
index 520a42e..c6e5db8 100644
--- a/src/tests/sorter_tests.cpp
+++ b/src/tests/sorter_tests.cpp
@@ -32,7 +32,7 @@
 
 using namespace mesos;
 
-using mesos::internal::master::allocator::DRFSorter;
+using mesos::master::allocator::DRFSorter;
 
 using std::list;
 using std::string;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/state_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/state_tests.cpp b/src/tests/state_tests.cpp
index ef2e96f..541feca 100644
--- a/src/tests/state_tests.cpp
+++ b/src/tests/state_tests.cpp
@@ -61,27 +61,28 @@
 #endif
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::log;
+using namespace mesos::log;
 
 using namespace process;
 
-using state::LevelDBStorage;
-using state::Operation;
-using state::Storage;
+using mesos::state::InMemoryStorage;
+using mesos::state::LevelDBStorage;
+using mesos::state::LogStorage;
+using mesos::state::Operation;
+using mesos::state::Storage;
 #ifdef MESOS_HAS_JAVA
-using state::ZooKeeperStorage;
+using mesos::state::ZooKeeperStorage;
 #endif
 
-using state::protobuf::State;
-using state::protobuf::Variable;
+using mesos::state::protobuf::State;
+using mesos::state::protobuf::Variable;
 
 using std::list;
 using std::set;
 using std::string;
 using std::vector;
 
-using mesos::internal::tests::TemporaryDirectoryTest;
+using mesos::tests::TemporaryDirectoryTest;
 
 typedef mesos::internal::Registry::Slaves Slaves;
 typedef mesos::internal::Registry::Slave Slave;
@@ -336,7 +337,7 @@ public:
 protected:
   virtual void SetUp()
   {
-    storage = new state::InMemoryStorage();
+    storage = new InMemoryStorage();
     state = new State(storage);
   }
 
@@ -346,7 +347,7 @@ protected:
     delete storage;
   }
 
-  state::Storage* storage;
+  Storage* storage;
   State* state;
 };
 
@@ -405,7 +406,7 @@ protected:
   virtual void SetUp()
   {
     os::rmdir(path);
-    storage = new state::LevelDBStorage(path);
+    storage = new LevelDBStorage(path);
     state = new State(storage);
   }
 
@@ -416,7 +417,7 @@ protected:
     os::rmdir(path);
   }
 
-  state::Storage* storage;
+  Storage* storage;
   State* state;
 
 private:
@@ -500,7 +501,7 @@ protected:
     pids.insert(replica2->pid());
 
     log = new Log(2, path1, pids);
-    storage = new state::LogStorage(log, 1024);
+    storage = new LogStorage(log, 1024);
     state = new State(storage);
   }
 
@@ -515,7 +516,7 @@ protected:
     TemporaryDirectoryTest::TearDown();
   }
 
-  state::Storage* storage;
+  Storage* storage;
   State* state;
 
   Replica* replica2;
@@ -698,7 +699,7 @@ protected:
   virtual void SetUp()
   {
     ZooKeeperTest::SetUp();
-    storage = new state::ZooKeeperStorage(
+    storage = new ZooKeeperStorage(
         server->connectString(),
         NO_TIMEOUT,
         "/state/");
@@ -712,7 +713,7 @@ protected:
     ZooKeeperTest::TearDown();
   }
 
-  state::Storage* storage;
+  Storage* storage;
   State* state;
 };
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/status_update_manager_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/status_update_manager_tests.cpp b/src/tests/status_update_manager_tests.cpp
index 6ff7320..2158cfe 100644
--- a/src/tests/status_update_manager_tests.cpp
+++ b/src/tests/status_update_manager_tests.cpp
@@ -48,12 +48,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/utils.cpp
----------------------------------------------------------------------
diff --git a/src/tests/utils.cpp b/src/tests/utils.cpp
index f4f90b9..2427469 100644
--- a/src/tests/utils.cpp
+++ b/src/tests/utils.cpp
@@ -34,7 +34,6 @@
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 void TemporaryDirectoryTest::SetUp()
@@ -71,5 +70,4 @@ void TemporaryDirectoryTest::TearDown()
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/utils.hpp
----------------------------------------------------------------------
diff --git a/src/tests/utils.hpp b/src/tests/utils.hpp
index 5c86fd4..3aea47c 100644
--- a/src/tests/utils.hpp
+++ b/src/tests/utils.hpp
@@ -26,7 +26,6 @@
 #include <stout/option.hpp>
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Test fixture for creating a temporary directory for each test.
@@ -43,7 +42,6 @@ private:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_UTILS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/values_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/values_tests.cpp b/src/tests/values_tests.cpp
index 35d3b3e..dd59db8 100644
--- a/src/tests/values_tests.cpp
+++ b/src/tests/values_tests.cpp
@@ -29,8 +29,7 @@
 #include "master/master.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::values;
+using namespace mesos::values;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/zookeeper.cpp
----------------------------------------------------------------------
diff --git a/src/tests/zookeeper.cpp b/src/tests/zookeeper.cpp
index 08cab86..4f96dfa 100644
--- a/src/tests/zookeeper.cpp
+++ b/src/tests/zookeeper.cpp
@@ -47,7 +47,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 const Duration ZooKeeperTest::NO_TIMEOUT = Seconds(10);
@@ -183,5 +182,4 @@ ZooKeeperTest::TestWatcher::awaitEvent(
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/zookeeper.hpp
----------------------------------------------------------------------
diff --git a/src/tests/zookeeper.hpp b/src/tests/zookeeper.hpp
index d8f1cb3..615e23a 100644
--- a/src/tests/zookeeper.hpp
+++ b/src/tests/zookeeper.hpp
@@ -31,7 +31,6 @@
 #include "tests/zookeeper_test_server.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Helper for invoking ZooKeeper::get(path, ...) in order to check the
@@ -62,7 +61,7 @@ inline ::testing::AssertionResult AssertZKGet(
 }
 
 #define ASSERT_ZK_GET(expected, zk, path)                               \
-  ASSERT_PRED_FORMAT3(mesos::internal::tests::AssertZKGet, expected, zk, path)
+  ASSERT_PRED_FORMAT3(mesos::tests::AssertZKGet, expected, zk, path)
 
 
 // A fixture for tests that need to interact with a ZooKeeper server
@@ -130,7 +129,6 @@ protected:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __ZOOKEEPER_TEST_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/zookeeper_test_server.cpp
----------------------------------------------------------------------
diff --git a/src/tests/zookeeper_test_server.cpp b/src/tests/zookeeper_test_server.cpp
index d92ab8a..984b6a6 100644
--- a/src/tests/zookeeper_test_server.cpp
+++ b/src/tests/zookeeper_test_server.cpp
@@ -36,7 +36,6 @@ using org::apache::zookeeper::server::NIOServerCnxnFactory;
 using org::apache::zookeeper::server::ZooKeeperServer;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 ZooKeeperTestServer::ZooKeeperTestServer()
@@ -163,5 +162,4 @@ int ZooKeeperTestServer::startNetwork()
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/zookeeper_test_server.hpp
----------------------------------------------------------------------
diff --git a/src/tests/zookeeper_test_server.hpp b/src/tests/zookeeper_test_server.hpp
index e415ce6..cfc9706 100644
--- a/src/tests/zookeeper_test_server.hpp
+++ b/src/tests/zookeeper_test_server.hpp
@@ -30,7 +30,6 @@
 #include "zookeeper/zookeeper.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // An in-process ZooKeeper server that can be manipulated to control
@@ -81,7 +80,6 @@ private:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __ZOOKEEPER_TEST_SERVER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/zookeeper_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/zookeeper_tests.cpp b/src/tests/zookeeper_tests.cpp
index 183008e..40081ef 100644
--- a/src/tests/zookeeper_tests.cpp
+++ b/src/tests/zookeeper_tests.cpp
@@ -36,8 +36,8 @@
 
 #include "tests/zookeeper.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos;
+using namespace mesos::tests;
 using namespace process;
 using namespace zookeeper;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/usage/main.cpp
----------------------------------------------------------------------
diff --git a/src/usage/main.cpp b/src/usage/main.cpp
index 97f55e9..e987f0c 100644
--- a/src/usage/main.cpp
+++ b/src/usage/main.cpp
@@ -100,7 +100,7 @@ int main(int argc, char** argv)
     return -1;
   }
 
-  Try<ResourceStatistics> statistics = mesos::internal::usage(flags.pid.get());
+  Try<ResourceStatistics> statistics = mesos::usage(flags.pid.get());
 
   if (statistics.isError()) {
     cerr << "Failed to get usage: " << statistics.error() << endl;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/usage/usage.cpp
----------------------------------------------------------------------
diff --git a/src/usage/usage.cpp b/src/usage/usage.cpp
index bb6c0ea..4ddf075 100644
--- a/src/usage/usage.cpp
+++ b/src/usage/usage.cpp
@@ -28,7 +28,6 @@
 #include "usage/usage.hpp"
 
 namespace mesos {
-namespace internal {
 
 Try<ResourceStatistics> usage(pid_t pid, bool mem, bool cpus)
 {
@@ -80,5 +79,4 @@ Try<ResourceStatistics> usage(pid_t pid, bool mem, bool cpus)
   return statistics;
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/usage/usage.hpp
----------------------------------------------------------------------
diff --git a/src/usage/usage.hpp b/src/usage/usage.hpp
index e0ad2e2..77e9d16 100644
--- a/src/usage/usage.hpp
+++ b/src/usage/usage.hpp
@@ -24,14 +24,12 @@
 #include "mesos/mesos.hpp"
 
 namespace mesos {
-namespace internal {
 
 // Collects resource usage of a process tree rooted at 'pid'. Only
 // collects the 'mem_*' values if 'mem' is true and the 'cpus_*'
 // values if 'cpus' is true.
 Try<ResourceStatistics> usage(pid_t pid, bool mem = true, bool cpus = true);
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __USAGE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/watcher/whitelist_watcher.cpp
----------------------------------------------------------------------
diff --git a/src/watcher/whitelist_watcher.cpp b/src/watcher/whitelist_watcher.cpp
index b6e73d7..2a1586e 100644
--- a/src/watcher/whitelist_watcher.cpp
+++ b/src/watcher/whitelist_watcher.cpp
@@ -32,7 +32,6 @@
 #include "watcher/whitelist_watcher.hpp"
 
 namespace mesos {
-namespace internal {
 
 using std::string;
 using std::vector;
@@ -107,5 +106,4 @@ void WhitelistWatcher::watch()
   delay(watchInterval, self(), &WhitelistWatcher::watch);
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/watcher/whitelist_watcher.hpp
----------------------------------------------------------------------
diff --git a/src/watcher/whitelist_watcher.hpp b/src/watcher/whitelist_watcher.hpp
index a1c1235..16ea839 100644
--- a/src/watcher/whitelist_watcher.hpp
+++ b/src/watcher/whitelist_watcher.hpp
@@ -29,7 +29,6 @@
 #include <stout/option.hpp>
 
 namespace mesos {
-namespace internal {
 
 // A whitelist may be (1) absent, (2) empty, (3) non-empty. The
 // watcher notifies the subscriber if the state of the whitelist
@@ -70,7 +69,6 @@ private:
   Option<hashset<std::string>> lastWhitelist;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __WATCHER_WHITELIST_WATCHER_HPP__


[4/4] mesos git commit: Internal deprecation 2: Moved internal protobufs from mesos::internal to mesos namespace.

Posted by nn...@apache.org.
Internal deprecation 2: Moved internal protobufs from mesos::internal to mesos namespace.

Changed package definition for protobufs defined in
messages/\{log,messages,state\}.proto and master/registry.proto to
remove "internal".

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


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

Branch: refs/heads/master
Commit: 830f4b3a9f949b43d381e39133eeb2046635cb83
Parents: 7c41857
Author: Kapil Arya <ka...@mesosphere.io>
Authored: Thu Feb 5 14:11:52 2015 -0800
Committer: Niklas Q. Nielsen <ni...@mesosphere.io>
Committed: Thu Feb 5 14:11:52 2015 -0800

----------------------------------------------------------------------
 src/common/parse.hpp              | 4 ++--
 src/common/type_utils.cpp         | 3 ---
 src/common/type_utils.hpp         | 3 ---
 src/log/consensus.hpp             | 2 --
 src/log/leveldb.cpp               | 2 --
 src/log/leveldb.hpp               | 2 --
 src/log/replica.hpp               | 2 --
 src/log/storage.hpp               | 2 --
 src/master/registry.proto         | 2 +-
 src/messages/log.proto            | 2 +-
 src/messages/messages.hpp         | 4 ----
 src/messages/messages.proto       | 4 ++--
 src/messages/state.proto          | 2 +-
 src/state/storage.hpp             | 2 --
 src/tests/rate_limiting_tests.cpp | 2 +-
 src/tests/state_tests.cpp         | 4 ++--
 16 files changed, 10 insertions(+), 32 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/common/parse.hpp
----------------------------------------------------------------------
diff --git a/src/common/parse.hpp b/src/common/parse.hpp
index ae581e5..772a1a5 100644
--- a/src/common/parse.hpp
+++ b/src/common/parse.hpp
@@ -56,7 +56,7 @@ inline Try<mesos::RateLimits> parse(const std::string& value)
 
 
 template<>
-inline Try<mesos::internal::Modules> parse(const std::string& value)
+inline Try<mesos::Modules> parse(const std::string& value)
 {
   // Convert from string or file to JSON.
   Try<JSON::Object> json = parse<JSON::Object>(value);
@@ -65,7 +65,7 @@ inline Try<mesos::internal::Modules> parse(const std::string& value)
   }
 
   // Convert from JSON to Protobuf.
-  return protobuf::parse<mesos::internal::Modules>(json.get());
+  return protobuf::parse<mesos::Modules>(json.get());
 }
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/common/type_utils.cpp
----------------------------------------------------------------------
diff --git a/src/common/type_utils.cpp b/src/common/type_utils.cpp
index 890df56..6062e43 100644
--- a/src/common/type_utils.cpp
+++ b/src/common/type_utils.cpp
@@ -155,8 +155,6 @@ bool operator == (const Volume& left, const Volume& right)
 }
 
 
-namespace internal {
-
 bool operator == (const Task& left, const Task& right)
 {
   return left.name() == right.name() &&
@@ -189,5 +187,4 @@ std::ostream& operator << (
     << " of framework " << update.framework_id();
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/common/type_utils.hpp
----------------------------------------------------------------------
diff --git a/src/common/type_utils.hpp b/src/common/type_utils.hpp
index b23eeb8..5c24c08 100644
--- a/src/common/type_utils.hpp
+++ b/src/common/type_utils.hpp
@@ -352,8 +352,6 @@ inline std::ostream& operator << (
 }
 
 
-namespace internal {
-
 bool operator == (const Task& left, const Task& right);
 
 
@@ -397,7 +395,6 @@ inline std::ostream& operator << (
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TYPE_UTILS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/log/consensus.hpp
----------------------------------------------------------------------
diff --git a/src/log/consensus.hpp b/src/log/consensus.hpp
index 102a65b..ee9e908 100644
--- a/src/log/consensus.hpp
+++ b/src/log/consensus.hpp
@@ -43,8 +43,6 @@
 namespace mesos {
 namespace log {
 
-using namespace mesos::internal::log;
-
 // Runs the promise phase (a.k.a., the prepare phase) in Paxos. This
 // phase has two purposes. First, the proposer asks promises from a
 // quorum of replicas not to accept writes from proposers with lower

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/log/leveldb.cpp
----------------------------------------------------------------------
diff --git a/src/log/leveldb.cpp b/src/log/leveldb.cpp
index 6441405..1d67942 100644
--- a/src/log/leveldb.cpp
+++ b/src/log/leveldb.cpp
@@ -39,8 +39,6 @@ using std::string;
 namespace mesos {
 namespace log {
 
-using namespace mesos::internal::log;
-
 class Varint64Comparator : public leveldb::Comparator
 {
 public:

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/log/leveldb.hpp
----------------------------------------------------------------------
diff --git a/src/log/leveldb.hpp b/src/log/leveldb.hpp
index 60ea949..8f5df5b 100644
--- a/src/log/leveldb.hpp
+++ b/src/log/leveldb.hpp
@@ -30,8 +30,6 @@
 namespace mesos {
 namespace log {
 
-using namespace mesos::internal::log;
-
 // Concrete implementation of the storage interface using leveldb.
 class LevelDBStorage : public Storage
 {

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/log/replica.hpp
----------------------------------------------------------------------
diff --git a/src/log/replica.hpp b/src/log/replica.hpp
index 7563ecd..b260208 100644
--- a/src/log/replica.hpp
+++ b/src/log/replica.hpp
@@ -35,8 +35,6 @@
 namespace mesos {
 namespace log {
 
-using namespace mesos::internal::log;
-
 namespace protocol {
 
 // Some replica protocol declarations.

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/log/storage.hpp
----------------------------------------------------------------------
diff --git a/src/log/storage.hpp b/src/log/storage.hpp
index 5d238e7..5e81f4e 100644
--- a/src/log/storage.hpp
+++ b/src/log/storage.hpp
@@ -32,8 +32,6 @@
 namespace mesos {
 namespace log {
 
-using namespace mesos::internal::log;
-
 // Abstract interface for reading and writing records.
 class Storage
 {

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/master/registry.proto
----------------------------------------------------------------------
diff --git a/src/master/registry.proto b/src/master/registry.proto
index a1995e5..29a3097 100644
--- a/src/master/registry.proto
+++ b/src/master/registry.proto
@@ -18,7 +18,7 @@
 
 import "mesos/mesos.proto";
 
-package mesos.internal;
+package mesos;
 
 message Registry {
   message Master {

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/messages/log.proto
----------------------------------------------------------------------
diff --git a/src/messages/log.proto b/src/messages/log.proto
index d73b33f..12b3572 100644
--- a/src/messages/log.proto
+++ b/src/messages/log.proto
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package mesos.internal.log;
+package mesos.log;
 
 
 // Represents a "promise" that a replica has made. A promise is

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/messages/messages.hpp
----------------------------------------------------------------------
diff --git a/src/messages/messages.hpp b/src/messages/messages.hpp
index ac222ca..77840bc 100644
--- a/src/messages/messages.hpp
+++ b/src/messages/messages.hpp
@@ -30,10 +30,6 @@
 
 #include "messages/messages.pb.h"
 
-// TODO(karya): We should remove this once the internal protobufs are
-// moved from mesos::internal to mesos namespace.
-using namespace mesos::internal;
-
 namespace messages {
 
 template <typename T>

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/messages/messages.proto
----------------------------------------------------------------------
diff --git a/src/messages/messages.proto b/src/messages/messages.proto
index 8d86517..44122bd 100644
--- a/src/messages/messages.proto
+++ b/src/messages/messages.proto
@@ -18,12 +18,12 @@
 
 import "mesos/mesos.proto";
 
-package mesos.internal;
+package mesos;
 
 // TODO(benh): Provide comments for each of these messages. Also,
 // consider splitting these messages into different "packages" which
 // represent which messages get handled by which components (e.g., the
-// "mesos.internal.executor" package includes messages that the
+// "mesos.executor" package includes messages that the
 // executor handles).
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/messages/state.proto
----------------------------------------------------------------------
diff --git a/src/messages/state.proto b/src/messages/state.proto
index 15071c2..7fc4883 100644
--- a/src/messages/state.proto
+++ b/src/messages/state.proto
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package mesos.internal.state;
+package mesos.state;
 
 // Describes a state entry, a versioned (via a UUID) key/value pair.
 message Entry {

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/state/storage.hpp
----------------------------------------------------------------------
diff --git a/src/state/storage.hpp b/src/state/storage.hpp
index 190c7a3..f5cd607 100644
--- a/src/state/storage.hpp
+++ b/src/state/storage.hpp
@@ -32,8 +32,6 @@
 namespace mesos {
 namespace state {
 
-using namespace mesos::internal::state;
-
 class Storage
 {
 public:

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/tests/rate_limiting_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/rate_limiting_tests.cpp b/src/tests/rate_limiting_tests.cpp
index 34c2267..8b55bff 100644
--- a/src/tests/rate_limiting_tests.cpp
+++ b/src/tests/rate_limiting_tests.cpp
@@ -1053,7 +1053,7 @@ TEST_F(RateLimitingTest, CapacityReached)
   Future<Nothing> error;
   EXPECT_CALL(sched, error(
       driver,
-      "Message mesos.internal.RegisterFrameworkMessage dropped: capacity(2) "
+      "Message mesos.RegisterFrameworkMessage dropped: capacity(2) "
       "exceeded"))
     .WillOnce(FutureSatisfy(&error));
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/830f4b3a/src/tests/state_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/state_tests.cpp b/src/tests/state_tests.cpp
index 541feca..4a216e6 100644
--- a/src/tests/state_tests.cpp
+++ b/src/tests/state_tests.cpp
@@ -84,8 +84,8 @@ using std::vector;
 
 using mesos::tests::TemporaryDirectoryTest;
 
-typedef mesos::internal::Registry::Slaves Slaves;
-typedef mesos::internal::Registry::Slave Slave;
+typedef mesos::Registry::Slaves Slaves;
+typedef mesos::Registry::Slave Slave;
 
 void FetchAndStoreAndFetch(State* state)
 {


[3/4] mesos git commit: Internal deprecation 1: Removed mesos::internal namespace.

Posted by nn...@apache.org.
Internal deprecation 1: Removed mesos::internal namespace.

The namespace is redundant as it encapsulates a different namespace in
most cases.

While most of the changes remove the "internal" namespace from the
sources, there are two particular occasions where we do something
extra. In src/master/main.cpp and src/tests/state_tests.cpp, we
disambiguate `state::*` by doing a `using namespace mesos::state`.

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


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

Branch: refs/heads/master
Commit: 7c418577a2be6128bbe7ab82676e7f175c80b799
Parents: 17285e7
Author: Kapil Arya <ka...@mesosphere.io>
Authored: Thu Feb 5 14:10:49 2015 -0800
Committer: Niklas Q. Nielsen <ni...@mesosphere.io>
Committed: Thu Feb 5 14:10:49 2015 -0800

----------------------------------------------------------------------
 include/mesos/executor.hpp                      |  7 ++--
 include/mesos/scheduler.hpp                     | 11 +++---
 include/mesos/values.hpp                        |  2 --
 src/authentication/authenticatee.hpp            |  2 --
 src/authentication/authenticator.hpp            |  2 --
 src/authentication/cram_md5/authenticatee.hpp   |  2 --
 src/authentication/cram_md5/authenticator.hpp   |  2 --
 src/authentication/cram_md5/auxprop.cpp         |  2 --
 src/authentication/cram_md5/auxprop.hpp         |  2 --
 src/authorizer/authorizer.cpp                   |  2 --
 src/authorizer/authorizer.hpp                   |  2 --
 src/cli/execute.cpp                             |  1 -
 src/cli/resolve.cpp                             |  1 -
 src/common/attributes.cpp                       |  4 ---
 src/common/attributes.hpp                       |  4 ---
 src/common/build.cpp                            |  2 --
 src/common/build.hpp                            |  2 --
 src/common/date_utils.cpp                       |  2 --
 src/common/date_utils.hpp                       |  2 --
 src/common/factory.hpp                          |  6 ++--
 src/common/http.cpp                             |  2 --
 src/common/http.hpp                             |  9 ++---
 src/common/lock.cpp                             |  2 --
 src/common/lock.hpp                             |  2 --
 src/common/protobuf_utils.cpp                   |  2 --
 src/common/protobuf_utils.hpp                   |  2 --
 src/common/resources.cpp                        |  2 +-
 src/common/type_utils.cpp                       |  3 +-
 src/common/values.cpp                           |  2 --
 src/credentials/credentials.hpp                 |  2 --
 src/docker/docker.cpp                           |  2 +-
 src/examples/balloon_framework.cpp              |  1 -
 src/examples/load_generator_framework.cpp       |  4 +--
 src/examples/low_level_scheduler_libprocess.cpp |  4 +--
 src/examples/low_level_scheduler_pthread.cpp    |  4 +--
 src/examples/test_authentication_modules.cpp    |  8 ++---
 src/examples/test_framework.cpp                 |  4 +--
 src/examples/test_hook_module.cpp               |  1 -
 src/examples/test_isolator_module.cpp           |  8 ++---
 src/exec/exec.cpp                               |  5 +--
 src/files/files.cpp                             |  2 --
 src/files/files.hpp                             |  2 --
 src/health-check/main.cpp                       |  6 ++--
 src/hook/hook.hpp                               |  2 --
 src/hook/manager.cpp                            |  2 --
 src/hook/manager.hpp                            |  2 --
 src/java/jni/org_apache_mesos_Log.cpp           |  2 +-
 .../org_apache_mesos_state_AbstractState.cpp    |  2 +-
 .../jni/org_apache_mesos_state_LevelDBState.cpp |  2 +-
 .../jni/org_apache_mesos_state_LogState.cpp     |  4 +--
 .../jni/org_apache_mesos_state_Variable.cpp     |  2 +-
 .../org_apache_mesos_state_ZooKeeperState.cpp   |  2 +-
 src/jvm/jvm.cpp                                 |  2 +-
 src/launcher/executor.cpp                       |  6 ++--
 src/launcher/fetcher.cpp                        |  3 +-
 src/linux/cgroups.cpp                           |  2 +-
 src/linux/fs.cpp                                |  2 --
 src/linux/fs.hpp                                |  2 --
 src/local/flags.hpp                             |  2 --
 src/local/local.cpp                             | 30 ++++++++---------
 src/local/local.hpp                             |  2 --
 src/local/main.cpp                              |  6 ++--
 src/log/catchup.cpp                             |  2 --
 src/log/catchup.hpp                             |  2 --
 src/log/consensus.cpp                           |  2 --
 src/log/consensus.hpp                           |  4 +--
 src/log/coordinator.cpp                         |  2 --
 src/log/coordinator.hpp                         |  2 --
 src/log/leveldb.cpp                             |  4 +--
 src/log/leveldb.hpp                             |  4 +--
 src/log/log.cpp                                 |  2 --
 src/log/log.hpp                                 |  2 --
 src/log/main.cpp                                |  3 +-
 src/log/recover.cpp                             |  2 --
 src/log/recover.hpp                             |  2 --
 src/log/replica.cpp                             |  2 --
 src/log/replica.hpp                             |  4 +--
 src/log/storage.hpp                             |  4 +--
 src/log/tool.hpp                                |  2 --
 src/log/tool/benchmark.cpp                      |  2 --
 src/log/tool/benchmark.hpp                      |  2 --
 src/log/tool/initialize.cpp                     |  2 --
 src/log/tool/initialize.hpp                     |  2 --
 src/log/tool/read.cpp                           |  2 --
 src/log/tool/read.hpp                           |  2 --
 src/log/tool/replica.cpp                        |  2 --
 src/log/tool/replica.hpp                        |  2 --
 src/logging/flags.hpp                           |  2 --
 src/logging/logging.cpp                         |  2 --
 src/logging/logging.hpp                         |  2 --
 src/master/allocator.hpp                        |  2 --
 src/master/constants.cpp                        |  2 --
 src/master/constants.hpp                        |  2 --
 src/master/contender.cpp                        |  2 --
 src/master/contender.hpp                        |  2 --
 src/master/detector.cpp                         |  2 --
 src/master/detector.hpp                         |  2 --
 src/master/drf_sorter.cpp                       |  2 --
 src/master/drf_sorter.hpp                       |  2 --
 src/master/flags.hpp                            |  2 --
 src/master/hierarchical_allocator_process.hpp   |  6 +---
 src/master/http.cpp                             |  4 +--
 src/master/main.cpp                             | 16 +++++----
 src/master/master.cpp                           |  2 --
 src/master/master.hpp                           |  2 --
 src/master/metrics.cpp                          |  2 --
 src/master/metrics.hpp                          |  2 --
 src/master/registrar.cpp                        |  6 ++--
 src/master/registrar.hpp                        |  2 --
 src/master/repairer.cpp                         |  2 --
 src/master/repairer.hpp                         |  2 --
 src/master/sorter.hpp                           |  2 --
 src/master/validation.cpp                       |  2 --
 src/master/validation.hpp                       |  2 --
 src/messages/messages.hpp                       |  4 +++
 src/module/authenticatee.hpp                    | 10 +++---
 src/module/authenticator.hpp                    | 10 +++---
 src/module/hook.hpp                             | 10 +++---
 src/module/isolator.hpp                         | 10 +++---
 src/module/manager.cpp                          |  1 -
 src/module/manager.hpp                          |  6 ++--
 src/sched/constants.cpp                         |  2 --
 src/sched/constants.hpp                         |  2 --
 src/sched/flags.hpp                             |  2 --
 src/sched/sched.cpp                             | 11 +++---
 src/scheduler/scheduler.cpp                     |  3 +-
 src/slave/constants.cpp                         |  2 --
 src/slave/constants.hpp                         |  2 --
 src/slave/containerizer/composing.cpp           |  2 --
 src/slave/containerizer/composing.hpp           |  2 --
 src/slave/containerizer/containerizer.cpp       |  2 --
 src/slave/containerizer/containerizer.hpp       |  2 --
 src/slave/containerizer/docker.cpp              |  4 +--
 src/slave/containerizer/docker.hpp              |  2 --
 .../containerizer/external_containerizer.cpp    |  2 --
 .../containerizer/external_containerizer.hpp    |  2 --
 src/slave/containerizer/fetcher.cpp             |  2 --
 src/slave/containerizer/fetcher.hpp             |  2 --
 src/slave/containerizer/isolator.cpp            |  2 --
 src/slave/containerizer/isolator.hpp            |  2 --
 .../isolators/cgroups/constants.hpp             |  2 --
 .../isolators/cgroups/cpushare.cpp              |  2 --
 .../isolators/cgroups/cpushare.hpp              |  2 --
 .../containerizer/isolators/cgroups/mem.cpp     |  2 --
 .../containerizer/isolators/cgroups/mem.hpp     |  2 --
 .../isolators/cgroups/perf_event.cpp            |  2 --
 .../isolators/cgroups/perf_event.hpp            |  2 --
 .../isolators/filesystem/shared.cpp             |  2 --
 .../isolators/filesystem/shared.hpp             |  2 --
 .../containerizer/isolators/namespaces/pid.cpp  |  2 --
 .../containerizer/isolators/namespaces/pid.hpp  |  2 --
 .../containerizer/isolators/network/helper.cpp  |  2 +-
 .../isolators/network/port_mapping.cpp          |  4 +--
 .../isolators/network/port_mapping.hpp          |  2 --
 src/slave/containerizer/isolators/posix.hpp     |  6 ++--
 .../containerizer/isolators/posix/disk.cpp      |  2 --
 .../containerizer/isolators/posix/disk.hpp      |  2 --
 src/slave/containerizer/launcher.cpp            |  2 --
 src/slave/containerizer/launcher.hpp            |  2 --
 src/slave/containerizer/linux_launcher.cpp      |  2 --
 src/slave/containerizer/linux_launcher.hpp      |  2 --
 src/slave/containerizer/mesos/containerizer.cpp |  2 --
 src/slave/containerizer/mesos/containerizer.hpp |  2 --
 src/slave/containerizer/mesos/launch.cpp        |  2 --
 src/slave/containerizer/mesos/launch.hpp        |  2 --
 src/slave/containerizer/mesos/main.cpp          |  2 +-
 src/slave/flags.hpp                             |  2 --
 src/slave/gc.cpp                                |  2 --
 src/slave/gc.hpp                                |  2 --
 src/slave/graceful_shutdown.cpp                 |  2 --
 src/slave/graceful_shutdown.hpp                 |  2 --
 src/slave/http.cpp                              |  4 +--
 src/slave/main.cpp                              |  4 +--
 src/slave/metrics.cpp                           |  2 --
 src/slave/metrics.hpp                           |  2 --
 src/slave/monitor.cpp                           |  2 --
 src/slave/monitor.hpp                           |  2 --
 src/slave/paths.cpp                             |  2 --
 src/slave/paths.hpp                             |  2 --
 src/slave/slave.cpp                             |  2 --
 src/slave/slave.hpp                             |  2 --
 src/slave/state.cpp                             |  2 --
 src/slave/state.hpp                             |  4 +--
 src/slave/status_update_manager.cpp             |  2 --
 src/slave/status_update_manager.hpp             |  2 --
 src/state/in_memory.cpp                         |  2 --
 src/state/in_memory.hpp                         |  2 --
 src/state/leveldb.cpp                           |  2 --
 src/state/leveldb.hpp                           |  2 --
 src/state/log.cpp                               |  4 +--
 src/state/log.hpp                               |  2 --
 src/state/protobuf.hpp                          |  2 --
 src/state/state.hpp                             |  2 --
 src/state/storage.hpp                           |  4 +--
 src/state/zookeeper.cpp                         |  2 --
 src/state/zookeeper.hpp                         |  2 --
 src/tests/attributes_tests.cpp                  |  1 -
 src/tests/authentication_tests.cpp              |  7 ++--
 src/tests/authorization_tests.cpp               |  3 +-
 src/tests/cgroups_isolator_tests.cpp            |  3 +-
 src/tests/cgroups_tests.cpp                     |  2 +-
 src/tests/cluster.hpp                           |  2 --
 src/tests/common/http_tests.cpp                 |  1 -
 src/tests/composing_containerizer_tests.cpp     |  5 ++-
 src/tests/containerizer.cpp                     |  2 --
 src/tests/containerizer.hpp                     |  2 --
 src/tests/containerizer_tests.cpp               |  3 +-
 src/tests/cram_md5_authentication_tests.cpp     |  4 +--
 src/tests/credentials_tests.cpp                 |  9 +++--
 src/tests/disk_quota_tests.cpp                  | 13 ++++----
 src/tests/docker_containerizer_tests.cpp        | 17 +++++-----
 src/tests/docker_tests.cpp                      |  3 +-
 src/tests/environment.cpp                       |  2 --
 src/tests/environment.hpp                       |  2 --
 src/tests/exception_tests.cpp                   |  7 ++--
 src/tests/external_containerizer_test.cpp       |  9 +++--
 src/tests/fault_tolerance_tests.cpp             | 13 ++++----
 src/tests/fetcher_tests.cpp                     | 13 ++++----
 src/tests/files_tests.cpp                       |  4 +--
 src/tests/flags.cpp                             |  2 --
 src/tests/flags.hpp                             |  2 --
 src/tests/fs_tests.cpp                          |  1 -
 src/tests/gc_tests.cpp                          | 11 +++---
 src/tests/group_tests.cpp                       |  4 +--
 src/tests/health_check_tests.cpp                | 15 ++++-----
 src/tests/hierarchical_allocator_tests.cpp      | 11 +++---
 src/tests/hook_tests.cpp                        |  7 ++--
 src/tests/isolator.hpp                          |  2 --
 src/tests/isolator_tests.cpp                    | 34 +++++++++----------
 src/tests/log_tests.cpp                         |  5 ++-
 src/tests/logging_tests.cpp                     |  2 +-
 src/tests/main.cpp                              |  8 ++---
 src/tests/master_allocator_tests.cpp            | 15 ++++-----
 src/tests/master_authorization_tests.cpp        |  9 +++--
 src/tests/master_contender_detector_tests.cpp   | 35 ++++++++++----------
 src/tests/master_slave_reconciliation_tests.cpp |  9 +++--
 src/tests/master_tests.cpp                      | 17 +++++-----
 src/tests/master_validation_tests.cpp           |  4 +--
 src/tests/mesos.cpp                             |  2 --
 src/tests/mesos.hpp                             |  2 --
 src/tests/metrics_tests.cpp                     |  7 ++--
 src/tests/module.cpp                            |  3 +-
 src/tests/module.hpp                            |  2 --
 src/tests/module_tests.cpp                      |  5 ++-
 src/tests/monitor_tests.cpp                     |  3 +-
 src/tests/ns_tests.cpp                          |  2 +-
 src/tests/partition_tests.cpp                   |  9 +++--
 src/tests/paths_tests.cpp                       |  2 --
 src/tests/port_mapping_tests.cpp                | 20 +++++------
 src/tests/protobuf_io_tests.cpp                 |  3 +-
 src/tests/rate_limiting_tests.cpp               |  9 ++---
 src/tests/reconciliation_tests.cpp              |  7 ++--
 src/tests/registrar_tests.cpp                   | 17 ++++------
 src/tests/registrar_zookeeper_tests.cpp         |  7 ++--
 src/tests/repair_tests.cpp                      |  5 ++-
 src/tests/resource_offers_tests.cpp             |  9 +++--
 src/tests/resources_tests.cpp                   |  5 ++-
 src/tests/scheduler_tests.cpp                   |  9 +++--
 src/tests/script.cpp                            |  2 --
 src/tests/script.hpp                            |  4 +--
 src/tests/shutdown_tests.cpp                    |  9 +++--
 src/tests/slave_recovery_tests.cpp              | 18 +++++-----
 src/tests/slave_tests.cpp                       | 17 +++++-----
 src/tests/sorter_tests.cpp                      |  2 +-
 src/tests/state_tests.cpp                       | 35 ++++++++++----------
 src/tests/status_update_manager_tests.cpp       |  7 ++--
 src/tests/utils.cpp                             |  2 --
 src/tests/utils.hpp                             |  2 --
 src/tests/values_tests.cpp                      |  3 +-
 src/tests/zookeeper.cpp                         |  2 --
 src/tests/zookeeper.hpp                         |  4 +--
 src/tests/zookeeper_test_server.cpp             |  2 --
 src/tests/zookeeper_test_server.hpp             |  2 --
 src/tests/zookeeper_tests.cpp                   |  4 +--
 src/usage/main.cpp                              |  2 +-
 src/usage/usage.cpp                             |  2 --
 src/usage/usage.hpp                             |  2 --
 src/watcher/whitelist_watcher.cpp               |  2 --
 src/watcher/whitelist_watcher.hpp               |  2 --
 279 files changed, 368 insertions(+), 789 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/include/mesos/executor.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/executor.hpp b/include/mesos/executor.hpp
index f3cd3cc..cf82b04 100644
--- a/include/mesos/executor.hpp
+++ b/include/mesos/executor.hpp
@@ -50,10 +50,7 @@ namespace mesos {
 
 // A few forward declarations.
 class ExecutorDriver;
-
-namespace internal {
 class ExecutorProcess;
-}
 
 // Callback interface to be implemented by frameworks' executors. Note
 // that only one callback will be invoked at a time, so it is not
@@ -229,12 +226,12 @@ public:
   virtual Status sendFrameworkMessage(const std::string& data);
 
 private:
-  friend class internal::ExecutorProcess;
+  friend class ExecutorProcess;
 
   Executor* executor;
 
   // Libprocess process for communicating with slave.
-  internal::ExecutorProcess* process;
+  ExecutorProcess* process;
 
   // Mutex to enforce all non-callbacks are execute serially.
   pthread_mutex_t mutex;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/include/mesos/scheduler.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/scheduler.hpp b/include/mesos/scheduler.hpp
index 9d6a205..31256c1 100644
--- a/include/mesos/scheduler.hpp
+++ b/include/mesos/scheduler.hpp
@@ -47,17 +47,14 @@
 namespace mesos {
 
 // A few forward declarations.
+class MasterDetector;
 class SchedulerDriver;
+class SchedulerProcess;
 
 namespace scheduler {
 class MesosProcess;
 } // namespace scheduler {
 
-namespace internal {
-class MasterDetector;
-class SchedulerProcess;
-} // namespace internal {
-
 
 // Callback interface to be implemented by frameworks' schedulers.
 // Note that only one callback will be invoked at a time, so it is not
@@ -402,7 +399,7 @@ public:
 
 protected:
   // Used to detect (i.e., choose) the master.
-  internal::MasterDetector* detector;
+  MasterDetector* detector;
 
 private:
   void initialize();
@@ -412,7 +409,7 @@ private:
   std::string master;
 
   // Used for communicating with the master.
-  internal::SchedulerProcess* process;
+  SchedulerProcess* process;
 
   // URL for the master (e.g., zk://, file://, etc).
   std::string url;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/include/mesos/values.hpp
----------------------------------------------------------------------
diff --git a/include/mesos/values.hpp b/include/mesos/values.hpp
index c61f9e8..e957677 100644
--- a/include/mesos/values.hpp
+++ b/include/mesos/values.hpp
@@ -56,13 +56,11 @@ Value::Set& operator -= (Value::Set& left, const Value::Set& right);
 std::ostream& operator << (std::ostream& stream, const Value::Text& value);
 bool operator == (const Value::Text& left, const Value::Text& right);
 
-namespace internal {
 namespace values {
 
 Try<Value> parse(const std::string& text);
 
 } // namespace values {
-} // namespace internal {
 
 } // namespace mesos {
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/authenticatee.hpp
----------------------------------------------------------------------
diff --git a/src/authentication/authenticatee.hpp b/src/authentication/authenticatee.hpp
index 361083b..95798d7 100644
--- a/src/authentication/authenticatee.hpp
+++ b/src/authentication/authenticatee.hpp
@@ -27,7 +27,6 @@
 #include <stout/try.hpp>
 
 namespace mesos {
-namespace internal {
 
 class Authenticatee
 {
@@ -52,7 +51,6 @@ public:
     const mesos::Credential& credential) = 0;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __AUTHENTICATEE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/authenticator.hpp
----------------------------------------------------------------------
diff --git a/src/authentication/authenticator.hpp b/src/authentication/authenticator.hpp
index 460494a..abc2a23 100644
--- a/src/authentication/authenticator.hpp
+++ b/src/authentication/authenticator.hpp
@@ -28,7 +28,6 @@
 #include <stout/try.hpp>
 
 namespace mesos {
-namespace internal {
 
 // Note that this interface definition is not hardened yet and will
 // slightly change within the next release. See MESOS-2050.
@@ -51,7 +50,6 @@ public:
   virtual process::Future<Option<std::string>> authenticate(void) = 0;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __AUTHENTICATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/cram_md5/authenticatee.hpp
----------------------------------------------------------------------
diff --git a/src/authentication/cram_md5/authenticatee.hpp b/src/authentication/cram_md5/authenticatee.hpp
index 5d35598..70e1509 100644
--- a/src/authentication/cram_md5/authenticatee.hpp
+++ b/src/authentication/cram_md5/authenticatee.hpp
@@ -41,7 +41,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 namespace cram_md5 {
 
 // Forward declaration.
@@ -420,7 +419,6 @@ inline process::Future<bool> CRAMMD5Authenticatee::authenticate(
 }
 
 } // namespace cram_md5 {
-} // namespace internal {
 } // namespace mesos {
 
 #endif //__AUTHENTICATION_CRAM_MD5_AUTHENTICATEE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/cram_md5/authenticator.hpp
----------------------------------------------------------------------
diff --git a/src/authentication/cram_md5/authenticator.hpp b/src/authentication/cram_md5/authenticator.hpp
index d739a02..fa34f76 100644
--- a/src/authentication/cram_md5/authenticator.hpp
+++ b/src/authentication/cram_md5/authenticator.hpp
@@ -43,7 +43,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 namespace cram_md5 {
 
 // Forward declaration.
@@ -511,7 +510,6 @@ process::Future<Option<std::string>> CRAMMD5Authenticator::authenticate(void)
 }
 
 } // namespace cram_md5 {
-} // namespace internal {
 } // namespace mesos {
 
 #endif //__AUTHENTICATION_CRAM_MD5_AUTHENTICATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/cram_md5/auxprop.cpp
----------------------------------------------------------------------
diff --git a/src/authentication/cram_md5/auxprop.cpp b/src/authentication/cram_md5/auxprop.cpp
index cf503a2..5ff9755 100644
--- a/src/authentication/cram_md5/auxprop.cpp
+++ b/src/authentication/cram_md5/auxprop.cpp
@@ -24,7 +24,6 @@ using std::list;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace cram_md5 {
 
 // Storage for the static members.
@@ -200,5 +199,4 @@ int InMemoryAuxiliaryPropertyPlugin::initialize(
 }
 
 } // namespace cram_md5 {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authentication/cram_md5/auxprop.hpp
----------------------------------------------------------------------
diff --git a/src/authentication/cram_md5/auxprop.hpp b/src/authentication/cram_md5/auxprop.hpp
index b894386..d036b11 100644
--- a/src/authentication/cram_md5/auxprop.hpp
+++ b/src/authentication/cram_md5/auxprop.hpp
@@ -30,7 +30,6 @@
 #include <stout/option.hpp>
 
 namespace mesos {
-namespace internal {
 namespace cram_md5 {
 
 struct Property
@@ -90,7 +89,6 @@ private:
 };
 
 } // namespace cram_md5 {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __AUTHENTICATION_CRAM_MD5_AUXPROP_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authorizer/authorizer.cpp
----------------------------------------------------------------------
diff --git a/src/authorizer/authorizer.cpp b/src/authorizer/authorizer.cpp
index 21e97e3..4f2b6a7 100644
--- a/src/authorizer/authorizer.cpp
+++ b/src/authorizer/authorizer.cpp
@@ -46,7 +46,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 
 class LocalAuthorizerProcess : public ProtobufProcess<LocalAuthorizerProcess>
 {
@@ -278,5 +277,4 @@ Future<bool> LocalAuthorizer::authorize(const ACL::ShutdownFramework& request)
       process, static_cast<F>(&LocalAuthorizerProcess::authorize), request);
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/authorizer/authorizer.hpp
----------------------------------------------------------------------
diff --git a/src/authorizer/authorizer.hpp b/src/authorizer/authorizer.hpp
index c039d94..66ddb92 100644
--- a/src/authorizer/authorizer.hpp
+++ b/src/authorizer/authorizer.hpp
@@ -31,7 +31,6 @@
 #include "mesos/mesos.hpp"
 
 namespace mesos {
-namespace internal {
 
 // Forward declaration.
 class LocalAuthorizerProcess;
@@ -81,7 +80,6 @@ private:
   LocalAuthorizerProcess* process;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif //__AUTHORIZER_AUTHORIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/cli/execute.cpp
----------------------------------------------------------------------
diff --git a/src/cli/execute.cpp b/src/cli/execute.cpp
index 77deec9..ea74049 100644
--- a/src/cli/execute.cpp
+++ b/src/cli/execute.cpp
@@ -36,7 +36,6 @@
 #include "hdfs/hdfs.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using process::UPID;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/cli/resolve.cpp
----------------------------------------------------------------------
diff --git a/src/cli/resolve.cpp b/src/cli/resolve.cpp
index a99b609..77bd443 100644
--- a/src/cli/resolve.cpp
+++ b/src/cli/resolve.cpp
@@ -33,7 +33,6 @@
 #include "messages/messages.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using process::Future;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/attributes.cpp
----------------------------------------------------------------------
diff --git a/src/common/attributes.cpp b/src/common/attributes.cpp
index aab114e..33da50c 100644
--- a/src/common/attributes.cpp
+++ b/src/common/attributes.cpp
@@ -53,9 +53,6 @@ std::ostream& operator << (std::ostream& stream, const Attribute& attribute)
 }
 
 
-namespace internal {
-
-
 bool Attributes::operator == (const Attributes& that) const
 {
   if (size() != that.size()) {
@@ -231,5 +228,4 @@ Value::Text Attributes::get(
 }
 
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/attributes.hpp
----------------------------------------------------------------------
diff --git a/src/common/attributes.hpp b/src/common/attributes.hpp
index 0a043d5..844bdbf 100644
--- a/src/common/attributes.hpp
+++ b/src/common/attributes.hpp
@@ -32,9 +32,6 @@ namespace mesos {
 std::ostream& operator << (std::ostream& stream, const Attribute& attribute);
 
 
-namespace internal {
-
-
 class Attributes
 {
 public:
@@ -118,7 +115,6 @@ private:
 };
 
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __ATTRIBUTES_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/build.cpp
----------------------------------------------------------------------
diff --git a/src/common/build.cpp b/src/common/build.cpp
index 9bef16e..90bd719 100644
--- a/src/common/build.cpp
+++ b/src/common/build.cpp
@@ -26,7 +26,6 @@
 #include "common/build.hpp"
 
 namespace mesos {
-namespace internal {
 namespace build {
 
 const std::string DATE = BUILD_DATE;
@@ -53,5 +52,4 @@ const Option<std::string> GIT_TAG = std::string(BUILD_GIT_TAG);
 const Option<std::string> GIT_TAG = None();
 #endif
 } // namespace build {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/build.hpp
----------------------------------------------------------------------
diff --git a/src/common/build.hpp b/src/common/build.hpp
index 7d61a06..9765c8f 100644
--- a/src/common/build.hpp
+++ b/src/common/build.hpp
@@ -21,7 +21,6 @@
 #include <string>
 
 namespace mesos {
-namespace internal {
 namespace build {
 
 extern const std::string DATE;
@@ -34,7 +33,6 @@ extern const Option<std::string> GIT_BRANCH;
 extern const Option<std::string> GIT_TAG;
 
 } // namespace build {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __BUILD_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/date_utils.cpp
----------------------------------------------------------------------
diff --git a/src/common/date_utils.cpp b/src/common/date_utils.cpp
index c5268bc..a148fd8 100644
--- a/src/common/date_utils.cpp
+++ b/src/common/date_utils.cpp
@@ -23,7 +23,6 @@
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace DateUtils {
 
 // Get the current date in the format used for Mesos IDs (YYYYMMDD-hhmmss).
@@ -39,5 +38,4 @@ string currentDate()
 }
 
 } // namespace DateUtils {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/date_utils.hpp
----------------------------------------------------------------------
diff --git a/src/common/date_utils.hpp b/src/common/date_utils.hpp
index 5f14a06..b11c8e0 100644
--- a/src/common/date_utils.hpp
+++ b/src/common/date_utils.hpp
@@ -22,7 +22,6 @@
 #include <string>
 
 namespace mesos {
-namespace internal {
 
 /**
  * Utility functions for dealing with dates.
@@ -35,7 +34,6 @@ std::string currentDate();
 
 
 } // namespace DateUtils {
-} // namespace internal {
 } // namespace mesos {
 
 #endif

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/factory.hpp
----------------------------------------------------------------------
diff --git a/src/common/factory.hpp b/src/common/factory.hpp
index bdddcf8..26f545b 100644
--- a/src/common/factory.hpp
+++ b/src/common/factory.hpp
@@ -49,7 +49,7 @@
 
 
 #define DECLARE_FACTORY(T, P) \
-  class T##Factory : public ::mesos::internal::factory::Factory<T, P> { \
+  class T##Factory : public ::mesos::factory::Factory<T, P> { \
     T##Factory(); \
     static T##Factory *instance; \
     static void initialize(); \
@@ -76,7 +76,8 @@
 
 // Helper classes for the factory macros.
 
-namespace mesos { namespace internal { namespace factory {
+namespace mesos {
+namespace factory {
 
 template<typename T, typename P> class Creator {
 public:
@@ -114,7 +115,6 @@ protected:
 };
 
 } // namespace factory {
-} // namespace internal {
 } // namespace mesos {
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/http.cpp
----------------------------------------------------------------------
diff --git a/src/common/http.cpp b/src/common/http.cpp
index 58a6065..576e2e4 100644
--- a/src/common/http.cpp
+++ b/src/common/http.cpp
@@ -32,7 +32,6 @@
 using std::vector;
 
 namespace mesos {
-namespace internal {
 
 // TODO(bmahler): Kill these in favor of automatic Proto->JSON
 // Conversion (when it becomes available).
@@ -191,5 +190,4 @@ JSON::Object model(
 }
 
 
-}  // namespace internal {
 }  // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/http.hpp
----------------------------------------------------------------------
diff --git a/src/common/http.hpp b/src/common/http.hpp
index afce7fe..bdb5948 100644
--- a/src/common/http.hpp
+++ b/src/common/http.hpp
@@ -25,14 +25,12 @@
 
 #include <stout/json.hpp>
 
-namespace mesos {
-
-class Resources;
+#include "messages/messages.hpp"
 
-namespace internal {
+namespace mesos {
 
 class Attributes;
-class Task;
+class Resources;
 
 
 JSON::Object model(const Resources& resources);
@@ -47,7 +45,6 @@ JSON::Object model(
     const TaskState& state,
     const std::vector<TaskStatus>& statuses);
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __COMMON_HTTP_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/lock.cpp
----------------------------------------------------------------------
diff --git a/src/common/lock.cpp b/src/common/lock.cpp
index bb8ea3a..a52d3ff 100644
--- a/src/common/lock.cpp
+++ b/src/common/lock.cpp
@@ -19,7 +19,6 @@
 #include "lock.hpp"
 
 namespace mesos {
-namespace internal {
 
 Lock::Lock(pthread_mutex_t* _mutex)
   : mutex(_mutex), locked(false)
@@ -51,5 +50,4 @@ Lock::~Lock()
   unlock();
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/lock.hpp
----------------------------------------------------------------------
diff --git a/src/common/lock.hpp b/src/common/lock.hpp
index 988dff5..fbe04e0 100644
--- a/src/common/lock.hpp
+++ b/src/common/lock.hpp
@@ -22,7 +22,6 @@
 #include <pthread.h>
 
 namespace mesos {
-namespace internal {
 
 // RAII class for locking pthread_mutexes.
 class Lock
@@ -39,7 +38,6 @@ private:
   bool locked;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOCK_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/protobuf_utils.cpp
----------------------------------------------------------------------
diff --git a/src/common/protobuf_utils.cpp b/src/common/protobuf_utils.cpp
index f9ca23a..345d96e 100644
--- a/src/common/protobuf_utils.cpp
+++ b/src/common/protobuf_utils.cpp
@@ -30,7 +30,6 @@
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace protobuf {
 
 bool isTerminalState(const TaskState& state)
@@ -155,5 +154,4 @@ MasterInfo createMasterInfo(const process::UPID& pid)
 }
 
 } // namespace protobuf {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/protobuf_utils.hpp
----------------------------------------------------------------------
diff --git a/src/common/protobuf_utils.hpp b/src/common/protobuf_utils.hpp
index a579391..82c6e4f 100644
--- a/src/common/protobuf_utils.hpp
+++ b/src/common/protobuf_utils.hpp
@@ -31,7 +31,6 @@ struct UPID;
 }
 
 namespace mesos {
-namespace internal {
 namespace protobuf {
 
 bool isTerminalState(const TaskState& state);
@@ -62,7 +61,6 @@ Option<bool> getTaskHealth(const Task& task);
 MasterInfo createMasterInfo(const process::UPID& pid);
 
 } // namespace protobuf {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __PROTOBUF_UTILS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/resources.cpp
----------------------------------------------------------------------
diff --git a/src/common/resources.cpp b/src/common/resources.cpp
index 308b886..98371f6 100644
--- a/src/common/resources.cpp
+++ b/src/common/resources.cpp
@@ -219,7 +219,7 @@ Try<Resource> Resources::parse(
     const string& value,
     const string& role)
 {
-  Try<Value> result = internal::values::parse(value);
+  Try<Value> result = values::parse(value);
   if (result.isError()) {
     return Error(
         "Failed to parse resource " + name +

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/type_utils.cpp
----------------------------------------------------------------------
diff --git a/src/common/type_utils.cpp b/src/common/type_utils.cpp
index fcc9eb0..890df56 100644
--- a/src/common/type_utils.cpp
+++ b/src/common/type_utils.cpp
@@ -138,8 +138,7 @@ bool operator == (const SlaveInfo& left, const SlaveInfo& right)
 {
   return left.hostname() == right.hostname() &&
     Resources(left.resources()) == Resources(right.resources()) &&
-    internal::Attributes(left.attributes()) ==
-    internal::Attributes(right.attributes()) &&
+    Attributes(left.attributes()) == Attributes(right.attributes()) &&
     left.has_id() == right.has_id() &&
     (!left.has_id() || (left.id() == right.id())) &&
     left.has_checkpoint() == right.has_checkpoint() &&

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/common/values.cpp
----------------------------------------------------------------------
diff --git a/src/common/values.cpp b/src/common/values.cpp
index 597c452..242f2a0 100644
--- a/src/common/values.cpp
+++ b/src/common/values.cpp
@@ -40,7 +40,6 @@ using std::vector;
 
 namespace mesos {
 
-namespace internal {
 namespace values {
 
 Try<Value> parse(const std::string& text)
@@ -129,7 +128,6 @@ Try<Value> parse(const std::string& text)
 }
 
 } // namespace values {
-} // namespace internal {
 
 
 ostream& operator << (ostream& stream, const Value::Scalar& scalar)

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/credentials/credentials.hpp
----------------------------------------------------------------------
diff --git a/src/credentials/credentials.hpp b/src/credentials/credentials.hpp
index 4cdadb1..9965858 100644
--- a/src/credentials/credentials.hpp
+++ b/src/credentials/credentials.hpp
@@ -28,7 +28,6 @@
 #include <stout/try.hpp>
 
 namespace mesos {
-namespace internal {
 namespace credentials {
 
 inline Result<Credentials> read(const std::string& path)
@@ -126,7 +125,6 @@ inline Result<Credential> readCredential(const std::string& path)
 }
 
 } // namespace credentials {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __CREDENTIALS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/docker/docker.cpp
----------------------------------------------------------------------
diff --git a/src/docker/docker.cpp b/src/docker/docker.cpp
index 3a485a2..94f16e7 100644
--- a/src/docker/docker.cpp
+++ b/src/docker/docker.cpp
@@ -43,7 +43,7 @@
 
 using namespace mesos;
 
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/balloon_framework.cpp
----------------------------------------------------------------------
diff --git a/src/examples/balloon_framework.cpp b/src/examples/balloon_framework.cpp
index c2337ba..08bb613 100644
--- a/src/examples/balloon_framework.cpp
+++ b/src/examples/balloon_framework.cpp
@@ -37,7 +37,6 @@
 #include "examples/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using std::cout;
 using std::endl;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/load_generator_framework.cpp
----------------------------------------------------------------------
diff --git a/src/examples/load_generator_framework.cpp b/src/examples/load_generator_framework.cpp
index 01a567b..f803d92 100644
--- a/src/examples/load_generator_framework.cpp
+++ b/src/examples/load_generator_framework.cpp
@@ -225,7 +225,7 @@ private:
 };
 
 
-class Flags : public mesos::internal::logging::Flags
+class Flags : public mesos::logging::Flags
 {
 public:
   Flags()
@@ -326,7 +326,7 @@ int main(int argc, char** argv)
   }
 
   // We want the logger to catch failure signals.
-  mesos::internal::logging::initialize(argv[0], flags, true);
+  mesos::logging::initialize(argv[0], flags, true);
 
   LoadGeneratorScheduler scheduler(flags.qps.get(), flags.duration);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/low_level_scheduler_libprocess.cpp
----------------------------------------------------------------------
diff --git a/src/examples/low_level_scheduler_libprocess.cpp b/src/examples/low_level_scheduler_libprocess.cpp
index a0ec131..cd04187 100644
--- a/src/examples/low_level_scheduler_libprocess.cpp
+++ b/src/examples/low_level_scheduler_libprocess.cpp
@@ -362,7 +362,7 @@ int main(int argc, char** argv)
     uri = path::join(os::getenv("MESOS_BUILD_DIR"), "src", "test-executor");
   }
 
-  mesos::internal::logging::Flags flags;
+  mesos::logging::Flags flags;
 
   string role;
   flags.add(&role,
@@ -388,7 +388,7 @@ int main(int argc, char** argv)
   }
 
   process::initialize();
-  internal::logging::initialize(argv[0], flags, true); // Catch signals.
+  logging::initialize(argv[0], flags, true); // Catch signals.
 
   FrameworkInfo framework;
   framework.set_user(""); // Have Mesos fill in the current user.

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/low_level_scheduler_pthread.cpp
----------------------------------------------------------------------
diff --git a/src/examples/low_level_scheduler_pthread.cpp b/src/examples/low_level_scheduler_pthread.cpp
index f05489a..f4bd4ac 100644
--- a/src/examples/low_level_scheduler_pthread.cpp
+++ b/src/examples/low_level_scheduler_pthread.cpp
@@ -422,7 +422,7 @@ int main(int argc, char** argv)
     uri = path::join(os::getenv("MESOS_BUILD_DIR"), "src", "test-executor");
   }
 
-  mesos::internal::logging::Flags flags;
+  mesos::logging::Flags flags;
 
   string role;
   flags.add(&role,
@@ -447,7 +447,7 @@ int main(int argc, char** argv)
     EXIT(1);
   }
 
-  internal::logging::initialize(argv[0], flags, true); // Catch signals.
+  logging::initialize(argv[0], flags, true); // Catch signals.
 
   FrameworkInfo framework;
   framework.set_user(""); // Have Mesos fill in the current user.

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/test_authentication_modules.cpp
----------------------------------------------------------------------
diff --git a/src/examples/test_authentication_modules.cpp b/src/examples/test_authentication_modules.cpp
index 6d32573..fd59fe4 100644
--- a/src/examples/test_authentication_modules.cpp
+++ b/src/examples/test_authentication_modules.cpp
@@ -30,8 +30,8 @@
 
 using namespace mesos;
 
-using mesos::internal::Authenticatee;
-using mesos::internal::Authenticator;
+using mesos::Authenticatee;
+using mesos::Authenticator;
 
 static bool compatible()
 {
@@ -41,7 +41,7 @@ static bool compatible()
 
 static Authenticatee* createCRAMMD5Authenticatee(const Parameters& parameters)
 {
-  return new mesos::internal::cram_md5::CRAMMD5Authenticatee();
+  return new mesos::cram_md5::CRAMMD5Authenticatee();
 }
 
 
@@ -57,7 +57,7 @@ mesos::modules::Module<Authenticatee> org_apache_mesos_TestCRAMMD5Authenticatee(
 
 static Authenticator* createCRAMMD5Authenticator(const Parameters& parameters)
 {
-  return new mesos::internal::cram_md5::CRAMMD5Authenticator();
+  return new mesos::cram_md5::CRAMMD5Authenticator();
 }
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/test_framework.cpp
----------------------------------------------------------------------
diff --git a/src/examples/test_framework.cpp b/src/examples/test_framework.cpp
index 7c062dc..3dfb6a0 100644
--- a/src/examples/test_framework.cpp
+++ b/src/examples/test_framework.cpp
@@ -191,7 +191,7 @@ int main(int argc, char** argv)
     uri = string(getenv("MESOS_BUILD_DIR")) + "/src/test-executor";
   }
 
-  mesos::internal::logging::Flags flags;
+  mesos::logging::Flags flags;
 
   string role;
   flags.add(&role,
@@ -216,7 +216,7 @@ int main(int argc, char** argv)
     exit(1);
   }
 
-  internal::logging::initialize(argv[0], flags, true); // Catch signals.
+  logging::initialize(argv[0], flags, true); // Catch signals.
 
   ExecutorInfo executor;
   executor.mutable_executor_id()->set_value("default");

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/test_hook_module.cpp
----------------------------------------------------------------------
diff --git a/src/examples/test_hook_module.cpp b/src/examples/test_hook_module.cpp
index 04fd43e..573ccb3 100644
--- a/src/examples/test_hook_module.cpp
+++ b/src/examples/test_hook_module.cpp
@@ -33,7 +33,6 @@
 using std::string;
 
 using namespace mesos;
-using namespace mesos::internal;
 
 // Must be kept in sync with variables of the same name in
 // tests/hook_tests.cpp.

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/examples/test_isolator_module.cpp
----------------------------------------------------------------------
diff --git a/src/examples/test_isolator_module.cpp b/src/examples/test_isolator_module.cpp
index dc107a1..3b92b04 100644
--- a/src/examples/test_isolator_module.cpp
+++ b/src/examples/test_isolator_module.cpp
@@ -29,10 +29,10 @@
 
 using namespace mesos;
 
-using mesos::internal::slave::Flags;
-using mesos::internal::slave::Isolator;
-using mesos::internal::slave::PosixCpuIsolatorProcess;
-using mesos::internal::slave::PosixMemIsolatorProcess;
+using mesos::slave::Flags;
+using mesos::slave::Isolator;
+using mesos::slave::PosixCpuIsolatorProcess;
+using mesos::slave::PosixMemIsolatorProcess;
 
 
 // The sole purpose of this function is just to exercise the

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/exec/exec.cpp
----------------------------------------------------------------------
diff --git a/src/exec/exec.cpp b/src/exec/exec.cpp
index aada246..38c8ee7 100644
--- a/src/exec/exec.cpp
+++ b/src/exec/exec.cpp
@@ -58,8 +58,7 @@
 #include "slave/state.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 using namespace process;
 
@@ -69,7 +68,6 @@ using process::wait; // Necessary on some OS's to disambiguate.
 
 
 namespace mesos {
-namespace internal {
 
 
 // A custom executor can be non-cooperative as it can block the
@@ -584,7 +582,6 @@ private:
   LinkedHashMap<TaskID, TaskInfo> tasks; // Unacknowledged tasks.
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/files/files.cpp
----------------------------------------------------------------------
diff --git a/src/files/files.cpp b/src/files/files.cpp
index 7b10240..58a74b1 100644
--- a/src/files/files.cpp
+++ b/src/files/files.cpp
@@ -52,7 +52,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 
 class FilesProcess : public Process<FilesProcess>
 {
@@ -472,5 +471,4 @@ void Files::detach(const string& name)
   dispatch(process, &FilesProcess::detach, name);
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/files/files.hpp
----------------------------------------------------------------------
diff --git a/src/files/files.hpp b/src/files/files.hpp
index 818087b..c8322d1 100644
--- a/src/files/files.hpp
+++ b/src/files/files.hpp
@@ -35,7 +35,6 @@
 #include <stout/path.hpp>
 
 namespace mesos {
-namespace internal {
 
 // Forward declarations.
 class FilesProcess;
@@ -140,7 +139,6 @@ inline JSON::Object jsonFileInfo(const std::string& path,
   return file;
 }
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __FILES_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/health-check/main.cpp
----------------------------------------------------------------------
diff --git a/src/health-check/main.cpp b/src/health-check/main.cpp
index a4ce742..260b872 100644
--- a/src/health-check/main.cpp
+++ b/src/health-check/main.cpp
@@ -60,7 +60,6 @@ using std::vector;
 using process::UPID;
 
 namespace mesos {
-namespace internal {
 
 using namespace process;
 
@@ -251,7 +250,6 @@ private:
   process::Time startTime;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 
@@ -359,7 +357,7 @@ int main(int argc, char** argv)
   TaskID taskID;
   taskID.set_value(flags.task_id.get());
 
-  internal::HealthCheckerProcess process(
+  HealthCheckerProcess process(
     check.get(),
     flags.executor.get(),
     taskID);
@@ -368,7 +366,7 @@ int main(int argc, char** argv)
 
   process::Future<Nothing> checking =
     process::dispatch(
-      process, &internal::HealthCheckerProcess::healthCheck);
+      process, &HealthCheckerProcess::healthCheck);
 
   checking.await();
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/hook/hook.hpp
----------------------------------------------------------------------
diff --git a/src/hook/hook.hpp b/src/hook/hook.hpp
index 9401e03..e31b7c9 100644
--- a/src/hook/hook.hpp
+++ b/src/hook/hook.hpp
@@ -28,7 +28,6 @@
 #include "slave/slave.hpp"
 
 namespace mesos {
-namespace internal {
 
 class Hook
 {
@@ -70,7 +69,6 @@ public:
   }
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __HOOK_HOOK_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/hook/manager.cpp
----------------------------------------------------------------------
diff --git a/src/hook/manager.cpp b/src/hook/manager.cpp
index 6bf1ef7..c14dcca 100644
--- a/src/hook/manager.cpp
+++ b/src/hook/manager.cpp
@@ -39,7 +39,6 @@ using std::vector;
 using mesos::modules::ModuleManager;
 
 namespace mesos {
-namespace internal {
 
 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER;
 static hashmap<string, Hook*> availableHooks;
@@ -147,5 +146,4 @@ void HookManager::slaveRemoveExecutorHook(
   }
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/hook/manager.hpp
----------------------------------------------------------------------
diff --git a/src/hook/manager.hpp b/src/hook/manager.hpp
index aadc17a..2de59b7 100644
--- a/src/hook/manager.hpp
+++ b/src/hook/manager.hpp
@@ -28,7 +28,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 
 class HookManager
 {
@@ -54,7 +53,6 @@ public:
       const ExecutorInfo& executorInfo);
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __HOOK_MANAGER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_Log.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_Log.cpp b/src/java/jni/org_apache_mesos_Log.cpp
index 1e1d821..3261b61 100644
--- a/src/java/jni/org_apache_mesos_Log.cpp
+++ b/src/java/jni/org_apache_mesos_Log.cpp
@@ -33,7 +33,7 @@
 #include "org_apache_mesos_Log_Writer.h"
 
 using namespace mesos;
-using namespace mesos::internal::log;
+using namespace mesos::log;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_state_AbstractState.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_state_AbstractState.cpp b/src/java/jni/org_apache_mesos_state_AbstractState.cpp
index 1accc8a..d7e6cb5 100644
--- a/src/java/jni/org_apache_mesos_state_AbstractState.cpp
+++ b/src/java/jni/org_apache_mesos_state_AbstractState.cpp
@@ -14,7 +14,7 @@
 #include "construct.hpp"
 #include "convert.hpp"
 
-using namespace mesos::internal::state;
+using namespace mesos::state;
 
 using process::Future;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_state_LevelDBState.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_state_LevelDBState.cpp b/src/java/jni/org_apache_mesos_state_LevelDBState.cpp
index 30f6309..27e8905 100644
--- a/src/java/jni/org_apache_mesos_state_LevelDBState.cpp
+++ b/src/java/jni/org_apache_mesos_state_LevelDBState.cpp
@@ -8,7 +8,7 @@
 #include "construct.hpp"
 #include "convert.hpp"
 
-using namespace mesos::internal::state;
+using namespace mesos::state;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_state_LogState.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_state_LogState.cpp b/src/java/jni/org_apache_mesos_state_LogState.cpp
index 6382b9c..dc1e49d 100644
--- a/src/java/jni/org_apache_mesos_state_LogState.cpp
+++ b/src/java/jni/org_apache_mesos_state_LogState.cpp
@@ -12,8 +12,8 @@
 #include "construct.hpp"
 #include "convert.hpp"
 
-using namespace mesos::internal::log;
-using namespace mesos::internal::state;
+using namespace mesos::log;
+using namespace mesos::state;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_state_Variable.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_state_Variable.cpp b/src/java/jni/org_apache_mesos_state_Variable.cpp
index 4d840ce..b600996 100644
--- a/src/java/jni/org_apache_mesos_state_Variable.cpp
+++ b/src/java/jni/org_apache_mesos_state_Variable.cpp
@@ -4,7 +4,7 @@
 
 #include "state/state.hpp"
 
-using namespace mesos::internal::state;
+using namespace mesos::state;
 
 extern "C" {
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/java/jni/org_apache_mesos_state_ZooKeeperState.cpp
----------------------------------------------------------------------
diff --git a/src/java/jni/org_apache_mesos_state_ZooKeeperState.cpp b/src/java/jni/org_apache_mesos_state_ZooKeeperState.cpp
index c40e685..7b81760 100644
--- a/src/java/jni/org_apache_mesos_state_ZooKeeperState.cpp
+++ b/src/java/jni/org_apache_mesos_state_ZooKeeperState.cpp
@@ -10,7 +10,7 @@
 #include "construct.hpp"
 #include "convert.hpp"
 
-using namespace mesos::internal::state;
+using namespace mesos::state;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/jvm/jvm.cpp
----------------------------------------------------------------------
diff --git a/src/jvm/jvm.cpp b/src/jvm/jvm.cpp
index d33a655..38fedfc 100644
--- a/src/jvm/jvm.cpp
+++ b/src/jvm/jvm.cpp
@@ -60,7 +60,7 @@ Try<Jvm*> Jvm::create(
   std::string libJvmPath = os::getenv("JAVA_JVM_LIBRARY", false);
 
   if (libJvmPath.empty()) {
-    libJvmPath = mesos::internal::build::JAVA_JVM_LIBRARY;
+    libJvmPath = mesos::build::JAVA_JVM_LIBRARY;
   }
 
   static DynamicLibrary* libJvm = new DynamicLibrary();

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/launcher/executor.cpp
----------------------------------------------------------------------
diff --git a/src/launcher/executor.cpp b/src/launcher/executor.cpp
index 1cf28f1..8c2f2e6 100644
--- a/src/launcher/executor.cpp
+++ b/src/launcher/executor.cpp
@@ -59,7 +59,7 @@
 #include "slave/graceful_shutdown.hpp"
 
 using process::wait; // Necessary on some OS's to disambiguate.
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 using std::cout;
 using std::cerr;
@@ -68,7 +68,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 
 using namespace process;
 
@@ -590,7 +589,6 @@ private:
   CommandExecutorProcess* process;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 
@@ -683,7 +681,7 @@ int main(int argc, char** argv)
   if (path.empty()) {
     path = os::realpath(dirname(argv[0])).get();
   }
-  mesos::internal::CommandExecutor executor(override, path, shutdownTimeout);
+  mesos::CommandExecutor executor(override, path, shutdownTimeout);
   mesos::MesosExecutorDriver driver(&executor);
   return driver.run() == mesos::DRIVER_STOPPED ? 0 : 1;
 }

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/launcher/fetcher.cpp
----------------------------------------------------------------------
diff --git a/src/launcher/fetcher.cpp b/src/launcher/fetcher.cpp
index fed0105..5b2d86d 100644
--- a/src/launcher/fetcher.cpp
+++ b/src/launcher/fetcher.cpp
@@ -35,7 +35,6 @@
 #include "logging/logging.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using mesos::fetcher::FetcherInfo;
 
@@ -257,7 +256,7 @@ int main(int argc, char* argv[])
 {
   GOOGLE_PROTOBUF_VERIFY_VERSION;
 
-  mesos::internal::logging::Flags flags;
+  mesos::logging::Flags flags;
 
   Try<Nothing> load = flags.load("MESOS_", argc, argv);
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/linux/cgroups.cpp
----------------------------------------------------------------------
diff --git a/src/linux/cgroups.cpp b/src/linux/cgroups.cpp
index 0b136e1..b6f75b1 100644
--- a/src/linux/cgroups.cpp
+++ b/src/linux/cgroups.cpp
@@ -62,7 +62,7 @@
 using namespace process;
 
 // TODO(benh): Move linux/fs.hpp out of 'mesos- namespace.
-using namespace mesos::internal;
+using namespace mesos;
 
 using std::dec;
 using std::getline;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/linux/fs.cpp
----------------------------------------------------------------------
diff --git a/src/linux/fs.cpp b/src/linux/fs.cpp
index b01d14c..d17d3ab 100644
--- a/src/linux/fs.cpp
+++ b/src/linux/fs.cpp
@@ -30,7 +30,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace fs {
 
 
@@ -179,5 +178,4 @@ Try<Nothing> unmount(const std::string& target, int flags)
 
 
 } // namespace fs {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/linux/fs.hpp
----------------------------------------------------------------------
diff --git a/src/linux/fs.hpp b/src/linux/fs.hpp
index ac8b5f4..9368d36 100644
--- a/src/linux/fs.hpp
+++ b/src/linux/fs.hpp
@@ -32,7 +32,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace fs {
 
 
@@ -142,7 +141,6 @@ Try<Nothing> unmount(const std::string& target, int flags = 0);
 
 
 } // namespace fs {
-} // namespace internal {
 } // namespace mesos {
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/local/flags.hpp
----------------------------------------------------------------------
diff --git a/src/local/flags.hpp b/src/local/flags.hpp
index 54e8831..16be2ad 100644
--- a/src/local/flags.hpp
+++ b/src/local/flags.hpp
@@ -24,7 +24,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace local {
 
 class Flags : public logging::Flags
@@ -42,7 +41,6 @@ public:
 };
 
 } // namespace local {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOCAL_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/local/local.cpp
----------------------------------------------------------------------
diff --git a/src/local/local.cpp b/src/local/local.cpp
index 76e73a4..3b128c4 100644
--- a/src/local/local.cpp
+++ b/src/local/local.cpp
@@ -63,23 +63,23 @@
 #include "state/protobuf.hpp"
 #include "state/storage.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::log;
+using namespace mesos;
+using namespace mesos::log;
 
-using mesos::internal::master::allocator::Allocator;
-using mesos::internal::master::allocator::AllocatorProcess;
-using mesos::internal::master::allocator::DRFSorter;
-using mesos::internal::master::allocator::HierarchicalDRFAllocatorProcess;
+using mesos::master::allocator::Allocator;
+using mesos::master::allocator::AllocatorProcess;
+using mesos::master::allocator::DRFSorter;
+using mesos::master::allocator::HierarchicalDRFAllocatorProcess;
 
-using mesos::internal::master::Master;
-using mesos::internal::master::Registrar;
-using mesos::internal::master::Repairer;
+using mesos::master::Master;
+using mesos::master::Registrar;
+using mesos::master::Repairer;
 
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::GarbageCollector;
-using mesos::internal::slave::Slave;
-using mesos::internal::slave::StatusUpdateManager;
+using mesos::slave::Containerizer;
+using mesos::slave::Fetcher;
+using mesos::slave::GarbageCollector;
+using mesos::slave::Slave;
+using mesos::slave::StatusUpdateManager;
 
 using process::Owned;
 using process::PID;
@@ -93,7 +93,6 @@ using std::vector;
 
 
 namespace mesos {
-namespace internal {
 namespace local {
 
 static Allocator* allocator = NULL;
@@ -340,5 +339,4 @@ void shutdown()
 }
 
 } // namespace local {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/local/local.hpp
----------------------------------------------------------------------
diff --git a/src/local/local.hpp b/src/local/local.hpp
index 0aa50ef..053434a 100644
--- a/src/local/local.hpp
+++ b/src/local/local.hpp
@@ -24,7 +24,6 @@
 #include "local/flags.hpp"
 
 namespace mesos {
-namespace internal {
 
 // Forward declarations.
 namespace master {
@@ -51,7 +50,6 @@ process::PID<master::Master> launch(
 void shutdown();
 
 } // namespace local {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MESOS_LOCAL_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/local/main.cpp
----------------------------------------------------------------------
diff --git a/src/local/main.cpp b/src/local/main.cpp
index a641b9e..7f12142 100644
--- a/src/local/main.cpp
+++ b/src/local/main.cpp
@@ -33,10 +33,10 @@
 
 #include "logging/logging.hpp"
 
-using namespace mesos::internal;
+using namespace mesos;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Slave;
 
 using std::cerr;
 using std::endl;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/catchup.cpp
----------------------------------------------------------------------
diff --git a/src/log/catchup.cpp b/src/log/catchup.cpp
index f7afc38..c33ecd8 100644
--- a/src/log/catchup.cpp
+++ b/src/log/catchup.cpp
@@ -38,7 +38,6 @@ using namespace process;
 using std::list;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 class CatchUpProcess : public Process<CatchUpProcess>
@@ -350,5 +349,4 @@ Future<Nothing> catchup(
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/catchup.hpp
----------------------------------------------------------------------
diff --git a/src/log/catchup.hpp b/src/log/catchup.hpp
index 5e23b57..9767c24 100644
--- a/src/log/catchup.hpp
+++ b/src/log/catchup.hpp
@@ -33,7 +33,6 @@
 #include "log/replica.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 // Catches-up a set of log positions in the local replica. The user of
@@ -53,7 +52,6 @@ extern process::Future<Nothing> catchup(
     const Duration& timeout = Seconds(10));
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_CATCHUP_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/consensus.cpp
----------------------------------------------------------------------
diff --git a/src/log/consensus.cpp b/src/log/consensus.cpp
index 59f80d0..7e33c69 100644
--- a/src/log/consensus.cpp
+++ b/src/log/consensus.cpp
@@ -40,7 +40,6 @@ using namespace process;
 using std::set;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 class ExplicitPromiseProcess : public Process<ExplicitPromiseProcess>
@@ -782,5 +781,4 @@ Future<Action> fill(
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/consensus.hpp
----------------------------------------------------------------------
diff --git a/src/log/consensus.hpp b/src/log/consensus.hpp
index ba41601..102a65b 100644
--- a/src/log/consensus.hpp
+++ b/src/log/consensus.hpp
@@ -41,9 +41,10 @@
 // to agree on previously written entries in the log.
 
 namespace mesos {
-namespace internal {
 namespace log {
 
+using namespace mesos::internal::log;
+
 // Runs the promise phase (a.k.a., the prepare phase) in Paxos. This
 // phase has two purposes. First, the proposer asks promises from a
 // quorum of replicas not to accept writes from proposers with lower
@@ -130,7 +131,6 @@ extern process::Future<Action> fill(
     uint64_t position);
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_CONSENSUS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/coordinator.cpp
----------------------------------------------------------------------
diff --git a/src/log/coordinator.cpp b/src/log/coordinator.cpp
index fe0c5f9..9a4383d 100644
--- a/src/log/coordinator.cpp
+++ b/src/log/coordinator.cpp
@@ -40,7 +40,6 @@ using namespace process;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 class CoordinatorProcess : public Process<CoordinatorProcess>
@@ -477,5 +476,4 @@ Future<Option<uint64_t> > Coordinator::truncate(uint64_t to)
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/coordinator.hpp
----------------------------------------------------------------------
diff --git a/src/log/coordinator.hpp b/src/log/coordinator.hpp
index b8a475f..e00d34d 100644
--- a/src/log/coordinator.hpp
+++ b/src/log/coordinator.hpp
@@ -32,7 +32,6 @@
 #include "log/replica.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 // Forward declaration.
@@ -76,7 +75,6 @@ private:
 };
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_COORDINATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/leveldb.cpp
----------------------------------------------------------------------
diff --git a/src/log/leveldb.cpp b/src/log/leveldb.cpp
index ad9e2f0..6441405 100644
--- a/src/log/leveldb.cpp
+++ b/src/log/leveldb.cpp
@@ -37,9 +37,10 @@
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
+using namespace mesos::internal::log;
+
 class Varint64Comparator : public leveldb::Comparator
 {
 public:
@@ -441,5 +442,4 @@ Try<Action> LevelDBStorage::read(uint64_t position)
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/leveldb.hpp
----------------------------------------------------------------------
diff --git a/src/log/leveldb.hpp b/src/log/leveldb.hpp
index 40a6d6f..60ea949 100644
--- a/src/log/leveldb.hpp
+++ b/src/log/leveldb.hpp
@@ -28,9 +28,10 @@
 #include "log/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
+using namespace mesos::internal::log;
+
 // Concrete implementation of the storage interface using leveldb.
 class LevelDBStorage : public Storage
 {
@@ -51,7 +52,6 @@ private:
 };
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_LEVELDB_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/log.cpp
----------------------------------------------------------------------
diff --git a/src/log/log.cpp b/src/log/log.cpp
index 598af69..cd7b6a8 100644
--- a/src/log/log.cpp
+++ b/src/log/log.cpp
@@ -46,7 +46,6 @@ using std::set;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 class LogProcess : public Process<LogProcess>
@@ -867,5 +866,4 @@ Future<Option<Log::Position> > Log::Writer::truncate(const Log::Position& to)
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/log.hpp
----------------------------------------------------------------------
diff --git a/src/log/log.hpp b/src/log/log.hpp
index 7c905c7..fac7d97 100644
--- a/src/log/log.hpp
+++ b/src/log/log.hpp
@@ -38,7 +38,6 @@
 #include "zookeeper/group.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 // Forward declarations.
@@ -232,7 +231,6 @@ private:
 };
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/main.cpp
----------------------------------------------------------------------
diff --git a/src/log/main.cpp b/src/log/main.cpp
index 348e887..2027ba0 100644
--- a/src/log/main.cpp
+++ b/src/log/main.cpp
@@ -33,8 +33,7 @@
 #include "log/tool/replica.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::log;
+using namespace mesos::log;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/recover.cpp
----------------------------------------------------------------------
diff --git a/src/log/recover.cpp b/src/log/recover.cpp
index 679741b..0ca7371 100644
--- a/src/log/recover.cpp
+++ b/src/log/recover.cpp
@@ -46,7 +46,6 @@ using namespace process;
 using std::set;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 // This class is responsible for executing the log recover protocol.
@@ -641,5 +640,4 @@ Future<Owned<Replica> > recover(
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/recover.hpp
----------------------------------------------------------------------
diff --git a/src/log/recover.hpp b/src/log/recover.hpp
index 6243c18..11e144e 100644
--- a/src/log/recover.hpp
+++ b/src/log/recover.hpp
@@ -31,7 +31,6 @@
 #include "log/replica.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 // Recovers a replica by catching up enough missing positions. A
@@ -58,7 +57,6 @@ extern process::Future<process::Owned<Replica> > recover(
     bool autoInitialize = false);
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_RECOVER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/replica.cpp
----------------------------------------------------------------------
diff --git a/src/log/replica.cpp b/src/log/replica.cpp
index dedfde4..2b748b3 100644
--- a/src/log/replica.cpp
+++ b/src/log/replica.cpp
@@ -44,7 +44,6 @@ using std::list;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 
 namespace protocol {
@@ -822,5 +821,4 @@ PID<ReplicaProcess> Replica::pid() const
 }
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/replica.hpp
----------------------------------------------------------------------
diff --git a/src/log/replica.hpp b/src/log/replica.hpp
index 33d3f1d..7563ecd 100644
--- a/src/log/replica.hpp
+++ b/src/log/replica.hpp
@@ -33,9 +33,10 @@
 #include "messages/log.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
+using namespace mesos::internal::log;
+
 namespace protocol {
 
 // Some replica protocol declarations.
@@ -102,7 +103,6 @@ private:
 };
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_REPLICA_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/storage.hpp
----------------------------------------------------------------------
diff --git a/src/log/storage.hpp b/src/log/storage.hpp
index 60bf37f..5d238e7 100644
--- a/src/log/storage.hpp
+++ b/src/log/storage.hpp
@@ -30,9 +30,10 @@
 #include "messages/log.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 
+using namespace mesos::internal::log;
+
 // Abstract interface for reading and writing records.
 class Storage
 {
@@ -59,7 +60,6 @@ public:
 };
 
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_STORAGE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool.hpp
----------------------------------------------------------------------
diff --git a/src/log/tool.hpp b/src/log/tool.hpp
index 656d3f6..3905159 100644
--- a/src/log/tool.hpp
+++ b/src/log/tool.hpp
@@ -25,7 +25,6 @@
 #include <stout/try.hpp>
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -45,7 +44,6 @@ public:
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_TOOL_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/benchmark.cpp
----------------------------------------------------------------------
diff --git a/src/log/tool/benchmark.cpp b/src/log/tool/benchmark.cpp
index 54d7898..096298e 100644
--- a/src/log/tool/benchmark.cpp
+++ b/src/log/tool/benchmark.cpp
@@ -52,7 +52,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -278,5 +277,4 @@ Try<Nothing> Benchmark::execute(int argc, char** argv)
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/benchmark.hpp
----------------------------------------------------------------------
diff --git a/src/log/tool/benchmark.hpp b/src/log/tool/benchmark.hpp
index e0109e2..d519a69 100644
--- a/src/log/tool/benchmark.hpp
+++ b/src/log/tool/benchmark.hpp
@@ -27,7 +27,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -62,7 +61,6 @@ private:
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_TOOL_BENCHMARK_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/initialize.cpp
----------------------------------------------------------------------
diff --git a/src/log/tool/initialize.cpp b/src/log/tool/initialize.cpp
index ccda7fb..f3d6337 100644
--- a/src/log/tool/initialize.cpp
+++ b/src/log/tool/initialize.cpp
@@ -36,7 +36,6 @@ using std::ostringstream;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -144,5 +143,4 @@ Try<Nothing> Initialize::execute(int argc, char** argv)
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/initialize.hpp
----------------------------------------------------------------------
diff --git a/src/log/tool/initialize.hpp b/src/log/tool/initialize.hpp
index 10ac269..f55225f 100644
--- a/src/log/tool/initialize.hpp
+++ b/src/log/tool/initialize.hpp
@@ -28,7 +28,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -57,7 +56,6 @@ private:
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_TOOL_INITIALIZE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/read.cpp
----------------------------------------------------------------------
diff --git a/src/log/tool/read.cpp b/src/log/tool/read.cpp
index d141385..4c6c30d 100644
--- a/src/log/tool/read.cpp
+++ b/src/log/tool/read.cpp
@@ -40,7 +40,6 @@ using std::ostringstream;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -186,5 +185,4 @@ Try<Nothing> Read::execute(int argc, char** argv)
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/read.hpp
----------------------------------------------------------------------
diff --git a/src/log/tool/read.hpp b/src/log/tool/read.hpp
index 9a6971b..1a077de 100644
--- a/src/log/tool/read.hpp
+++ b/src/log/tool/read.hpp
@@ -30,7 +30,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -61,7 +60,6 @@ private:
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_TOOL_READ_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/replica.cpp
----------------------------------------------------------------------
diff --git a/src/log/tool/replica.cpp b/src/log/tool/replica.cpp
index 3985fc7..0edc70a 100644
--- a/src/log/tool/replica.cpp
+++ b/src/log/tool/replica.cpp
@@ -37,7 +37,6 @@ using std::ostringstream;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -146,5 +145,4 @@ Try<Nothing> Replica::execute(int argc, char** argv)
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/log/tool/replica.hpp
----------------------------------------------------------------------
diff --git a/src/log/tool/replica.hpp b/src/log/tool/replica.hpp
index 7140c7e..9d8dfd0 100644
--- a/src/log/tool/replica.hpp
+++ b/src/log/tool/replica.hpp
@@ -29,7 +29,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace log {
 namespace tool {
 
@@ -62,7 +61,6 @@ private:
 
 } // namespace tool {
 } // namespace log {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOG_TOOL_REPLICA_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/logging/flags.hpp
----------------------------------------------------------------------
diff --git a/src/logging/flags.hpp b/src/logging/flags.hpp
index 4facb33..30b59b6 100644
--- a/src/logging/flags.hpp
+++ b/src/logging/flags.hpp
@@ -25,7 +25,6 @@
 #include <stout/option.hpp>
 
 namespace mesos {
-namespace internal {
 namespace logging {
 
 class Flags : public virtual flags::FlagsBase
@@ -80,7 +79,6 @@ public:
 };
 
 } // namespace logging {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOGGING_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/logging/logging.cpp
----------------------------------------------------------------------
diff --git a/src/logging/logging.cpp b/src/logging/logging.cpp
index 6b14575..9ae91d1 100644
--- a/src/logging/logging.cpp
+++ b/src/logging/logging.cpp
@@ -59,7 +59,6 @@ extern "C" void __cxa_pure_virtual()
 
 
 namespace mesos {
-namespace internal {
 namespace logging {
 
 // Persistent copy of argv0 since InitGoogleLogging requires the
@@ -233,5 +232,4 @@ Try<string> getLogFile(google::LogSeverity severity)
 }
 
 } // namespace logging {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/logging/logging.hpp
----------------------------------------------------------------------
diff --git a/src/logging/logging.hpp b/src/logging/logging.hpp
index f204d61..1984f9b 100644
--- a/src/logging/logging.hpp
+++ b/src/logging/logging.hpp
@@ -26,7 +26,6 @@
 #include "logging/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace logging {
 
 void initialize(
@@ -44,7 +43,6 @@ Try<std::string> getLogFile(google::LogSeverity severity);
 google::LogSeverity getLogSeverity(const std::string& logging_level);
 
 } // namespace logging {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LOGGING_LOGGING_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/allocator.hpp
----------------------------------------------------------------------
diff --git a/src/master/allocator.hpp b/src/master/allocator.hpp
index 44a7695..2149ea4 100644
--- a/src/master/allocator.hpp
+++ b/src/master/allocator.hpp
@@ -39,7 +39,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 class Master; // Forward declaration.
@@ -394,7 +393,6 @@ inline void Allocator::reviveOffers(
 
 } // namespace allocator {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __ALLOCATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/constants.cpp
----------------------------------------------------------------------
diff --git a/src/master/constants.cpp b/src/master/constants.cpp
index 9ee17e9..d3d0f71 100644
--- a/src/master/constants.cpp
+++ b/src/master/constants.cpp
@@ -25,7 +25,6 @@
 #include "master/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 const int MAX_OFFERS_PER_FRAMEWORK = 50;
@@ -45,5 +44,4 @@ const Duration ZOOKEEPER_SESSION_TIMEOUT = Seconds(10);
 const std::string DEFAULT_AUTHENTICATOR = "crammd5";
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/constants.hpp
----------------------------------------------------------------------
diff --git a/src/master/constants.hpp b/src/master/constants.hpp
index c386eab..ad3fe81 100644
--- a/src/master/constants.hpp
+++ b/src/master/constants.hpp
@@ -27,7 +27,6 @@
 #include <stout/duration.hpp>
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // TODO(benh): Add units after constants.
@@ -109,7 +108,6 @@ extern const Duration ZOOKEEPER_SESSION_TIMEOUT;
 extern const std::string DEFAULT_AUTHENTICATOR;
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_CONSTANTS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/contender.cpp
----------------------------------------------------------------------
diff --git a/src/master/contender.cpp b/src/master/contender.cpp
index c1bf82b..2270400 100644
--- a/src/master/contender.cpp
+++ b/src/master/contender.cpp
@@ -38,7 +38,6 @@ using namespace process;
 using namespace zookeeper;
 
 namespace mesos {
-namespace internal {
 
 using namespace master;
 
@@ -226,5 +225,4 @@ Future<Future<Nothing> > ZooKeeperMasterContenderProcess::contend()
   return candidacy.get();
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/contender.hpp
----------------------------------------------------------------------
diff --git a/src/master/contender.hpp b/src/master/contender.hpp
index 76beb5f..8e3e25a 100644
--- a/src/master/contender.hpp
+++ b/src/master/contender.hpp
@@ -34,7 +34,6 @@
 #include "zookeeper/url.hpp"
 
 namespace mesos {
-namespace internal {
 
 extern const Duration MASTER_CONTENDER_ZK_SESSION_TIMEOUT;
 
@@ -127,7 +126,6 @@ private:
   ZooKeeperMasterContenderProcess* process;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_CONTENDER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/detector.cpp
----------------------------------------------------------------------
diff --git a/src/master/detector.cpp b/src/master/detector.cpp
index 700eb9d..ebeca61 100644
--- a/src/master/detector.cpp
+++ b/src/master/detector.cpp
@@ -51,7 +51,6 @@ using std::set;
 using std::string;
 
 namespace mesos {
-namespace internal {
 
 const Duration MASTER_DETECTOR_ZK_SESSION_TIMEOUT = Seconds(10);
 
@@ -465,5 +464,4 @@ Future<Option<MasterInfo> > ZooKeeperMasterDetector::detect(
   return dispatch(process, &ZooKeeperMasterDetectorProcess::detect, previous);
 }
 
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/detector.hpp
----------------------------------------------------------------------
diff --git a/src/master/detector.hpp b/src/master/detector.hpp
index 2905e2b..4810748 100644
--- a/src/master/detector.hpp
+++ b/src/master/detector.hpp
@@ -35,7 +35,6 @@
 #include "zookeeper/url.hpp"
 
 namespace mesos {
-namespace internal {
 
 extern const Duration MASTER_DETECTOR_ZK_SESSION_TIMEOUT;
 
@@ -128,7 +127,6 @@ private:
   ZooKeeperMasterDetectorProcess* process;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_DETECTOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/drf_sorter.cpp
----------------------------------------------------------------------
diff --git a/src/master/drf_sorter.cpp b/src/master/drf_sorter.cpp
index 584e26c..0e4974c 100644
--- a/src/master/drf_sorter.cpp
+++ b/src/master/drf_sorter.cpp
@@ -26,7 +26,6 @@ using std::string;
 
 
 namespace mesos {
-namespace internal {
 namespace master {
 namespace allocator {
 
@@ -291,5 +290,4 @@ set<Client, DRFComparator>::iterator DRFSorter::find(const string& name)
 
 } // namespace allocator {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/drf_sorter.hpp
----------------------------------------------------------------------
diff --git a/src/master/drf_sorter.hpp b/src/master/drf_sorter.hpp
index 5a66313..8a16d28 100644
--- a/src/master/drf_sorter.hpp
+++ b/src/master/drf_sorter.hpp
@@ -30,7 +30,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace master {
 namespace allocator {
 
@@ -125,7 +124,6 @@ private:
 
 } // namespace allocator {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __DRF_SORTER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/flags.hpp
----------------------------------------------------------------------
diff --git a/src/master/flags.hpp b/src/master/flags.hpp
index e9f6fff..df2e9cb 100644
--- a/src/master/flags.hpp
+++ b/src/master/flags.hpp
@@ -38,7 +38,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 class Flags : public logging::Flags
@@ -411,7 +410,6 @@ public:
 };
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/hierarchical_allocator_process.hpp
----------------------------------------------------------------------
diff --git a/src/master/hierarchical_allocator_process.hpp b/src/master/hierarchical_allocator_process.hpp
index 6b44892..10fa6ec 100644
--- a/src/master/hierarchical_allocator_process.hpp
+++ b/src/master/hierarchical_allocator_process.hpp
@@ -40,7 +40,6 @@
 #include "master/sorter.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 namespace allocator {
 
@@ -399,7 +398,6 @@ HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::deactivateFramework(
 }
 
 
-namespace internal {
 
 // TODO(bmahler): Generalize this.
 template <typename Iterable>
@@ -412,7 +410,6 @@ Resources sum(const Iterable& resources)
   return total;
 }
 
-} // namespace internal {
 
 
 template <class RoleSorter, class FrameworkSorter>
@@ -445,7 +442,7 @@ HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::addSlave(
 
   slaves[slaveId] = Slave();
   slaves[slaveId].total = total;
-  slaves[slaveId].available = total - internal::sum(used.values());
+  slaves[slaveId].available = total - sum(used.values());
   slaves[slaveId].activated = true;
   slaves[slaveId].checkpoint = slaveInfo.checkpoint();
   slaves[slaveId].hostname = slaveInfo.hostname();
@@ -916,7 +913,6 @@ HierarchicalAllocatorProcess<RoleSorter, FrameworkSorter>::allocatable(
 
 } // namespace allocator {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __HIERARCHICAL_ALLOCATOR_PROCESS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/http.cpp
----------------------------------------------------------------------
diff --git a/src/master/http.cpp b/src/master/http.cpp
index 3981b18..138624d 100644
--- a/src/master/http.cpp
+++ b/src/master/http.cpp
@@ -76,11 +76,10 @@ using std::vector;
 
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // Pull in model overrides from common.
-using mesos::internal::model;
+using mesos::model;
 
 // Pull in definitions from process.
 using process::http::Response;
@@ -887,5 +886,4 @@ Result<Credential> Master::Http::authenticate(const Request& request)
 
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {


[2/4] mesos git commit: Internal deprecation 1: Removed mesos::internal namespace.

Posted by nn...@apache.org.
http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/main.cpp
----------------------------------------------------------------------
diff --git a/src/master/main.cpp b/src/master/main.cpp
index e5e76ce..a295490 100644
--- a/src/master/main.cpp
+++ b/src/master/main.cpp
@@ -65,9 +65,10 @@
 
 #include "zookeeper/detector.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::log;
-using namespace mesos::internal::master;
+using namespace mesos;
+using namespace mesos::log;
+using namespace mesos::master;
+using namespace mesos::state;
 using namespace zookeeper;
 
 using mesos::MasterInfo;
@@ -191,7 +192,7 @@ int main(int argc, char** argv)
   allocator::Allocator* allocator =
     new allocator::Allocator(allocatorProcess);
 
-  state::Storage* storage = NULL;
+  Storage* storage = NULL;
   Log* log = NULL;
 
   if (flags.registry == "in_memory") {
@@ -199,7 +200,7 @@ int main(int argc, char** argv)
       EXIT(1) << "Cannot use '--registry_strict' when using in-memory storage"
               << " based registry";
     }
-    storage = new state::InMemoryStorage();
+    storage = new InMemoryStorage();
   } else if (flags.registry == "replicated_log" ||
              flags.registry == "log_storage") {
     // TODO(bmahler): "log_storage" is present for backwards
@@ -255,7 +256,7 @@ int main(int argc, char** argv)
           set<UPID>(),
           flags.log_auto_initialize);
     }
-    storage = new state::LogStorage(log);
+    storage = new LogStorage(log);
   } else {
     EXIT(1) << "'" << flags.registry << "' is not a supported"
             << " option for registry persistence";
@@ -263,7 +264,8 @@ int main(int argc, char** argv)
 
   CHECK_NOTNULL(storage);
 
-  state::protobuf::State* state = new state::protobuf::State(storage);
+  mesos::state::protobuf::State* state =
+    new mesos::state::protobuf::State(storage);
   Registrar* registrar = new Registrar(flags, state);
   Repairer* repairer = new Repairer();
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/master.cpp
----------------------------------------------------------------------
diff --git a/src/master/master.cpp b/src/master/master.cpp
index 234bbec..22fece7 100644
--- a/src/master/master.cpp
+++ b/src/master/master.cpp
@@ -105,7 +105,6 @@ using process::metrics::Counter;
 using memory::shared_ptr;
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 using allocator::Allocator;
@@ -5071,5 +5070,4 @@ double Master::_resources_percent(const std::string& name)
 }
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/master.hpp
----------------------------------------------------------------------
diff --git a/src/master/master.hpp b/src/master/master.hpp
index dcfd38a..c3c77f8 100644
--- a/src/master/master.hpp
+++ b/src/master/master.hpp
@@ -65,7 +65,6 @@ class RateLimiter; // Forward declaration.
 }
 
 namespace mesos {
-namespace internal {
 
 // Forward declarations.
 namespace registry {
@@ -1268,7 +1267,6 @@ private:
 };
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/metrics.cpp
----------------------------------------------------------------------
diff --git a/src/master/metrics.cpp b/src/master/metrics.cpp
index 5fe71e3..0b3b91e 100644
--- a/src/master/metrics.cpp
+++ b/src/master/metrics.cpp
@@ -23,7 +23,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // Message counters are named with "messages_" prefix so they can
@@ -347,5 +346,4 @@ Metrics::~Metrics()
 
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/metrics.hpp
----------------------------------------------------------------------
diff --git a/src/master/metrics.hpp b/src/master/metrics.hpp
index 5e18f88..ee8b5bc 100644
--- a/src/master/metrics.hpp
+++ b/src/master/metrics.hpp
@@ -29,7 +29,6 @@
 #include <stout/hashmap.hpp>
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 class Master;
@@ -167,7 +166,6 @@ struct Metrics
 };
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_METRICS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/registrar.cpp
----------------------------------------------------------------------
diff --git a/src/master/registrar.cpp b/src/master/registrar.cpp
index 0831963..d2c5c3d 100644
--- a/src/master/registrar.cpp
+++ b/src/master/registrar.cpp
@@ -46,8 +46,8 @@
 
 #include "state/protobuf.hpp"
 
-using mesos::internal::state::protobuf::State;
-using mesos::internal::state::protobuf::Variable;
+using mesos::state::protobuf::State;
+using mesos::state::protobuf::Variable;
 
 using process::dispatch;
 using process::spawn;
@@ -73,7 +73,6 @@ using std::deque;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 using process::http::Response;
@@ -542,5 +541,4 @@ Future<bool> Registrar::apply(Owned<Operation> operation)
 }
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/registrar.hpp
----------------------------------------------------------------------
diff --git a/src/master/registrar.hpp b/src/master/registrar.hpp
index 6bc78c4..701b107 100644
--- a/src/master/registrar.hpp
+++ b/src/master/registrar.hpp
@@ -32,7 +32,6 @@
 #include "state/protobuf.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // Forward declaration.
@@ -123,7 +122,6 @@ private:
 };
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MASTER_REGISTRAR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/repairer.cpp
----------------------------------------------------------------------
diff --git a/src/master/repairer.cpp b/src/master/repairer.cpp
index 454e137..201ac25 100644
--- a/src/master/repairer.cpp
+++ b/src/master/repairer.cpp
@@ -21,7 +21,6 @@
 #include "master/repairer.hpp"
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 using std::string;
@@ -42,5 +41,4 @@ Repairer::~Repairer()
 
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/repairer.hpp
----------------------------------------------------------------------
diff --git a/src/master/repairer.hpp b/src/master/repairer.hpp
index d5c6b84..236b8de 100644
--- a/src/master/repairer.hpp
+++ b/src/master/repairer.hpp
@@ -22,7 +22,6 @@
 #include <mesos/mesos.hpp>
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 // An abstraction for recieve notification of unhealty nodes
@@ -38,7 +37,6 @@ public:
 };
 
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MESOS_MASTER_REPAIRER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/sorter.hpp
----------------------------------------------------------------------
diff --git a/src/master/sorter.hpp b/src/master/sorter.hpp
index 8915c61..1561201 100644
--- a/src/master/sorter.hpp
+++ b/src/master/sorter.hpp
@@ -25,7 +25,6 @@
 #include <mesos/resources.hpp>
 
 namespace mesos {
-namespace internal {
 namespace master {
 namespace allocator {
 
@@ -101,7 +100,6 @@ public:
 
 } // namespace allocator {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SORTER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/validation.cpp
----------------------------------------------------------------------
diff --git a/src/master/validation.cpp b/src/master/validation.cpp
index 2c4b16d..79dfaa1 100644
--- a/src/master/validation.cpp
+++ b/src/master/validation.cpp
@@ -40,7 +40,6 @@ using std::vector;
 using google::protobuf::RepeatedPtrField;
 
 namespace mesos {
-namespace internal {
 namespace master {
 namespace validation {
 
@@ -582,5 +581,4 @@ Option<Error> validate(
 
 } // namespace validation {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/master/validation.hpp
----------------------------------------------------------------------
diff --git a/src/master/validation.hpp b/src/master/validation.hpp
index 2d7416c..c312cdc 100644
--- a/src/master/validation.hpp
+++ b/src/master/validation.hpp
@@ -25,7 +25,6 @@
 #include <stout/option.hpp>
 
 namespace mesos {
-namespace internal {
 namespace master {
 
 class Master;
@@ -98,5 +97,4 @@ Option<Error> validate(
 
 } // namespace validation {
 } // namespace master {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/messages/messages.hpp
----------------------------------------------------------------------
diff --git a/src/messages/messages.hpp b/src/messages/messages.hpp
index 77840bc..ac222ca 100644
--- a/src/messages/messages.hpp
+++ b/src/messages/messages.hpp
@@ -30,6 +30,10 @@
 
 #include "messages/messages.pb.h"
 
+// TODO(karya): We should remove this once the internal protobufs are
+// moved from mesos::internal to mesos namespace.
+using namespace mesos::internal;
+
 namespace messages {
 
 template <typename T>

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/authenticatee.hpp
----------------------------------------------------------------------
diff --git a/src/module/authenticatee.hpp b/src/module/authenticatee.hpp
index bae37ce..a53016a 100644
--- a/src/module/authenticatee.hpp
+++ b/src/module/authenticatee.hpp
@@ -27,14 +27,14 @@ namespace mesos {
 namespace modules {
 
 template<>
-inline const char* kind<mesos::internal::Authenticatee>()
+inline const char* kind<mesos::Authenticatee>()
 {
   return "Authenticatee";
 }
 
 
 template <>
-struct Module<mesos::internal::Authenticatee> : ModuleBase
+struct Module<mesos::Authenticatee> : ModuleBase
 {
   Module(
       const char* _moduleApiVersion,
@@ -43,11 +43,11 @@ struct Module<mesos::internal::Authenticatee> : ModuleBase
       const char* _authorEmail,
       const char* _description,
       bool (*_compatible)(),
-      mesos::internal::Authenticatee* (*_create)(const Parameters& parameters))
+      mesos::Authenticatee* (*_create)(const Parameters& parameters))
     : ModuleBase(
         _moduleApiVersion,
         _mesosVersion,
-        mesos::modules::kind<mesos::internal::Authenticatee>(),
+        mesos::modules::kind<mesos::Authenticatee>(),
         _authorName,
         _authorEmail,
         _description,
@@ -55,7 +55,7 @@ struct Module<mesos::internal::Authenticatee> : ModuleBase
       create(_create)
   { }
 
-  mesos::internal::Authenticatee* (*create)(const Parameters& parameters);
+  mesos::Authenticatee* (*create)(const Parameters& parameters);
 };
 
 } // namespace modules {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/authenticator.hpp
----------------------------------------------------------------------
diff --git a/src/module/authenticator.hpp b/src/module/authenticator.hpp
index 9562338..156617b 100644
--- a/src/module/authenticator.hpp
+++ b/src/module/authenticator.hpp
@@ -27,14 +27,14 @@ namespace mesos {
 namespace modules {
 
 template<>
-inline const char* kind<mesos::internal::Authenticator>()
+inline const char* kind<mesos::Authenticator>()
 {
   return "Authenticator";
 }
 
 
 template <>
-struct Module<mesos::internal::Authenticator> : ModuleBase
+struct Module<mesos::Authenticator> : ModuleBase
 {
   Module(
       const char* _moduleApiVersion,
@@ -43,11 +43,11 @@ struct Module<mesos::internal::Authenticator> : ModuleBase
       const char* _authorEmail,
       const char* _description,
       bool (*_compatible)(),
-      mesos::internal::Authenticator* (*_create)(const Parameters& parameters))
+      mesos::Authenticator* (*_create)(const Parameters& parameters))
     : ModuleBase(
         _moduleApiVersion,
         _mesosVersion,
-        mesos::modules::kind<mesos::internal::Authenticator>(),
+        mesos::modules::kind<mesos::Authenticator>(),
         _authorName,
         _authorEmail,
         _description,
@@ -55,7 +55,7 @@ struct Module<mesos::internal::Authenticator> : ModuleBase
       create(_create)
   { }
 
-  mesos::internal::Authenticator* (*create)(const Parameters& parameters);
+  mesos::Authenticator* (*create)(const Parameters& parameters);
 };
 
 } // namespace modules {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/hook.hpp
----------------------------------------------------------------------
diff --git a/src/module/hook.hpp b/src/module/hook.hpp
index a7c51f2..c7edfba 100644
--- a/src/module/hook.hpp
+++ b/src/module/hook.hpp
@@ -28,14 +28,14 @@ namespace mesos {
 namespace modules {
 
 template<>
-inline const char* kind<mesos::internal::Hook>()
+inline const char* kind<mesos::Hook>()
 {
   return "Hook";
 }
 
 
 template <>
-struct Module<mesos::internal::Hook> : ModuleBase
+struct Module<mesos::Hook> : ModuleBase
 {
   Module(
       const char* _moduleApiVersion,
@@ -44,11 +44,11 @@ struct Module<mesos::internal::Hook> : ModuleBase
       const char* _authorEmail,
       const char* _description,
       bool (*_compatible)(),
-      mesos::internal::Hook* (*_create)(const Parameters& parameters))
+      mesos::Hook* (*_create)(const Parameters& parameters))
     : ModuleBase(
         _moduleApiVersion,
         _mesosVersion,
-        mesos::modules::kind<mesos::internal::Hook>(),
+        mesos::modules::kind<mesos::Hook>(),
         _authorName,
         _authorEmail,
         _description,
@@ -56,7 +56,7 @@ struct Module<mesos::internal::Hook> : ModuleBase
       create(_create)
   { }
 
-  mesos::internal::Hook* (*create)(const Parameters& parameters);
+  mesos::Hook* (*create)(const Parameters& parameters);
 };
 
 } // namespace modules {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/isolator.hpp
----------------------------------------------------------------------
diff --git a/src/module/isolator.hpp b/src/module/isolator.hpp
index 0f71e70..b5c86e3 100644
--- a/src/module/isolator.hpp
+++ b/src/module/isolator.hpp
@@ -28,14 +28,14 @@ namespace mesos {
 namespace modules {
 
 template<>
-inline const char* kind<mesos::internal::slave::Isolator>()
+inline const char* kind<mesos::slave::Isolator>()
 {
   return "Isolator";
 }
 
 
 template <>
-struct Module<mesos::internal::slave::Isolator> : ModuleBase
+struct Module<mesos::slave::Isolator> : ModuleBase
 {
   Module(
       const char* _moduleApiVersion,
@@ -44,12 +44,12 @@ struct Module<mesos::internal::slave::Isolator> : ModuleBase
       const char* _authorEmail,
       const char* _description,
       bool (*_compatible)(),
-      mesos::internal::slave::Isolator*
+      mesos::slave::Isolator*
         (*_create)(const Parameters& parameters))
     : ModuleBase(
         _moduleApiVersion,
         _mesosVersion,
-        mesos::modules::kind<mesos::internal::slave::Isolator>(),
+        mesos::modules::kind<mesos::slave::Isolator>(),
         _authorName,
         _authorEmail,
         _description,
@@ -57,7 +57,7 @@ struct Module<mesos::internal::slave::Isolator> : ModuleBase
       create(_create)
   { }
 
-  mesos::internal::slave::Isolator* (*create)(const Parameters& parameters);
+  mesos::slave::Isolator* (*create)(const Parameters& parameters);
 };
 
 } // namespace modules {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/manager.cpp
----------------------------------------------------------------------
diff --git a/src/module/manager.cpp b/src/module/manager.cpp
index 5abea26..573df82 100644
--- a/src/module/manager.cpp
+++ b/src/module/manager.cpp
@@ -38,7 +38,6 @@ using std::vector;
 using process::Owned;
 
 using namespace mesos;
-using namespace mesos::internal;
 using namespace mesos::modules;
 
 pthread_mutex_t ModuleManager::mutex = PTHREAD_MUTEX_INITIALIZER;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/module/manager.hpp
----------------------------------------------------------------------
diff --git a/src/module/manager.hpp b/src/module/manager.hpp
index 04c0b18..7a9d93b 100644
--- a/src/module/manager.hpp
+++ b/src/module/manager.hpp
@@ -63,13 +63,13 @@ public:
   //
   // NOTE: If loading fails at a particular library we don't unload
   // all of the already loaded libraries.
-  static Try<Nothing> load(const mesos::internal::Modules& modules);
+  static Try<Nothing> load(const Modules& modules);
 
   // create() should be called only after load().
   template <typename T>
   static Try<T*> create(const std::string& moduleName)
   {
-    mesos::internal::Lock lock(&mutex);
+    mesos::Lock lock(&mutex);
     if (!moduleBases.contains(moduleName)) {
       return Error(
           "Module '" + moduleName + "' unknown");
@@ -100,7 +100,7 @@ public:
   template <typename T>
   static bool contains(const std::string& moduleName)
   {
-    mesos::internal::Lock lock(&mutex);
+    mesos::Lock lock(&mutex);
     return (moduleBases.contains(moduleName) &&
             moduleBases[moduleName]->kind == stringify(kind<T>()));
   }

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/sched/constants.cpp
----------------------------------------------------------------------
diff --git a/src/sched/constants.cpp b/src/sched/constants.cpp
index 517ca5c..bc85d69 100644
--- a/src/sched/constants.cpp
+++ b/src/sched/constants.cpp
@@ -19,7 +19,6 @@
 #include "sched/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace scheduler {
 
 // NOTE: The default backoff factor for the scheduler (2s) is
@@ -34,5 +33,4 @@ const Duration REGISTRATION_RETRY_INTERVAL_MAX = Minutes(1);
 const std::string DEFAULT_AUTHENTICATEE = "crammd5";
 
 } // namespace scheduler {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/sched/constants.hpp
----------------------------------------------------------------------
diff --git a/src/sched/constants.hpp b/src/sched/constants.hpp
index ac497b2..d36d087 100644
--- a/src/sched/constants.hpp
+++ b/src/sched/constants.hpp
@@ -22,7 +22,6 @@
 #include <stout/duration.hpp>
 
 namespace mesos {
-namespace internal {
 namespace scheduler {
 
 // Default backoff interval used by the scheduler driver to wait
@@ -37,7 +36,6 @@ extern const Duration REGISTRATION_RETRY_INTERVAL_MAX;
 extern const std::string DEFAULT_AUTHENTICATEE;
 
 } // namespace scheduler {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SCHED_CONSTANTS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/sched/flags.hpp
----------------------------------------------------------------------
diff --git a/src/sched/flags.hpp b/src/sched/flags.hpp
index 4e0d56f..bfe01a3 100644
--- a/src/sched/flags.hpp
+++ b/src/sched/flags.hpp
@@ -30,7 +30,6 @@
 #include "sched/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace scheduler {
 
 class Flags : public logging::Flags
@@ -109,7 +108,6 @@ public:
 };
 
 } // namespace scheduler {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SCHED_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/sched/sched.cpp
----------------------------------------------------------------------
diff --git a/src/sched/sched.cpp b/src/sched/sched.cpp
index a822c00..ce6ff6d 100644
--- a/src/sched/sched.cpp
+++ b/src/sched/sched.cpp
@@ -85,8 +85,7 @@
 #include "sched/flags.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::master;
+using namespace mesos::master;
 using namespace mesos::scheduler;
 
 using namespace process;
@@ -100,7 +99,6 @@ using process::wait; // Necessary on some OS's to disambiguate.
 using utils::copy;
 
 namespace mesos {
-namespace internal {
 
 // The scheduler process (below) is responsible for interacting with
 // the master and responding to Mesos API calls from scheduler
@@ -117,7 +115,7 @@ public:
                    const Option<Credential>& _credential,
                    const string& schedulerId,
                    MasterDetector* _detector,
-                   const internal::scheduler::Flags& _flags,
+                   const scheduler::Flags& _flags,
                    pthread_mutex_t* _mutex,
                    pthread_cond_t* _cond)
       // We use a UUID here to ensure that the master can reliably
@@ -1199,7 +1197,7 @@ private:
 
   MasterDetector* detector;
 
-  const internal::scheduler::Flags flags;
+  const scheduler::Flags flags;
 
   hashmap<OfferID, hashmap<SlaveID, UPID> > savedOffers;
   hashmap<SlaveID, UPID> savedSlavePids;
@@ -1218,7 +1216,6 @@ private:
   bool reauthenticate;
 };
 
-} // namespace internal {
 } // namespace mesos {
 
 
@@ -1411,7 +1408,7 @@ Status MesosSchedulerDriver::start()
   }
 
   // Load scheduler flags.
-  internal::scheduler::Flags flags;
+  scheduler::Flags flags;
   Try<Nothing> load = flags.load("MESOS_");
 
   if (load.isError()) {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/scheduler/scheduler.cpp
----------------------------------------------------------------------
diff --git a/src/scheduler/scheduler.cpp b/src/scheduler/scheduler.cpp
index 44713ca..f5ee1b0 100644
--- a/src/scheduler/scheduler.cpp
+++ b/src/scheduler/scheduler.cpp
@@ -68,8 +68,7 @@
 #include "messages/messages.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::master;
+using namespace mesos::master;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/constants.cpp
----------------------------------------------------------------------
diff --git a/src/slave/constants.cpp b/src/slave/constants.cpp
index 83d9fc1..cdf5c46 100644
--- a/src/slave/constants.cpp
+++ b/src/slave/constants.cpp
@@ -23,7 +23,6 @@
 #include "slave/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 const Duration EXECUTOR_REGISTRATION_TIMEOUT = Minutes(1);
@@ -58,5 +57,4 @@ Duration MASTER_PING_TIMEOUT()
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/constants.hpp
----------------------------------------------------------------------
diff --git a/src/slave/constants.hpp b/src/slave/constants.hpp
index 761cfaf..7717abd 100644
--- a/src/slave/constants.hpp
+++ b/src/slave/constants.hpp
@@ -25,7 +25,6 @@
 #include <stout/duration.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // TODO(bmahler): It appears there may be a bug with gcc-4.1.2 in which these
@@ -119,7 +118,6 @@ extern const std::string DEFAULT_AUTHENTICATEE;
 Duration MASTER_PING_TIMEOUT();
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_CONSTANTS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/composing.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/composing.cpp b/src/slave/containerizer/composing.cpp
index a6ae817..6e3007e 100644
--- a/src/slave/containerizer/composing.cpp
+++ b/src/slave/containerizer/composing.cpp
@@ -39,7 +39,6 @@ using std::vector;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -550,5 +549,4 @@ Future<hashset<ContainerID> > ComposingContainerizerProcess::containers()
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/composing.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/composing.hpp b/src/slave/containerizer/composing.hpp
index f1e60b0..6518f2a 100644
--- a/src/slave/containerizer/composing.hpp
+++ b/src/slave/containerizer/composing.hpp
@@ -36,7 +36,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declaration.
@@ -94,7 +93,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __COMPOSING_CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/containerizer.cpp b/src/slave/containerizer/containerizer.cpp
index 421bb86..cf2ece8 100644
--- a/src/slave/containerizer/containerizer.cpp
+++ b/src/slave/containerizer/containerizer.cpp
@@ -51,7 +51,6 @@ using std::vector;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // TODO(idownes): Move this to the Containerizer interface to complete
@@ -308,5 +307,4 @@ map<string, string> executorEnvironment(
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/containerizer.hpp b/src/slave/containerizer/containerizer.hpp
index 129e60f..fd08b29 100644
--- a/src/slave/containerizer/containerizer.hpp
+++ b/src/slave/containerizer/containerizer.hpp
@@ -38,7 +38,6 @@
 #include "slave/containerizer/fetcher.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declaration.
@@ -139,7 +138,6 @@ std::map<std::string, std::string> executorEnvironment(
     const Duration& recoveryTimeout);
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/docker.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/docker.cpp b/src/slave/containerizer/docker.cpp
index 5f4b4ce..813ddf8 100644
--- a/src/slave/containerizer/docker.cpp
+++ b/src/slave/containerizer/docker.cpp
@@ -62,7 +62,6 @@ using std::vector;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using state::SlaveState;
@@ -1086,7 +1085,7 @@ Future<ResourceStatistics> DockerContainerizerProcess::__usage(
   // Note that here getting the root pid is enough because
   // the root process acts as an 'init' process in the docker
   // container, so no other child processes will escape it.
-  Try<ResourceStatistics> statistics = mesos::internal::usage(pid, true, true);
+  Try<ResourceStatistics> statistics = mesos::usage(pid, true, true);
   if (statistics.isError()) {
     return Failure(statistics.error());
   }
@@ -1344,5 +1343,4 @@ void DockerContainerizerProcess::remove(const string& container)
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/docker.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/docker.hpp b/src/slave/containerizer/docker.hpp
index b7bf54a..70114dc 100644
--- a/src/slave/containerizer/docker.hpp
+++ b/src/slave/containerizer/docker.hpp
@@ -28,7 +28,6 @@
 #include "slave/containerizer/containerizer.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Prefix used to name Docker containers in order to distinguish those
@@ -439,7 +438,6 @@ private:
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __DOCKER_CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/external_containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/external_containerizer.cpp b/src/slave/containerizer/external_containerizer.cpp
index 8d5a904..a31d66d 100644
--- a/src/slave/containerizer/external_containerizer.cpp
+++ b/src/slave/containerizer/external_containerizer.cpp
@@ -64,7 +64,6 @@ using tuples::tuple;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using state::ExecutorState;
@@ -1209,5 +1208,4 @@ Try<Subprocess> ExternalContainerizerProcess::invoke(
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/external_containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/external_containerizer.hpp b/src/slave/containerizer/external_containerizer.hpp
index 8363cec..1296878 100644
--- a/src/slave/containerizer/external_containerizer.hpp
+++ b/src/slave/containerizer/external_containerizer.hpp
@@ -36,7 +36,6 @@
 #include "slave/containerizer/launcher.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // The scheme an external containerizer programs have to adhere to is;
@@ -294,7 +293,6 @@ private:
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __EXTERNAL_CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/fetcher.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/fetcher.cpp b/src/slave/containerizer/fetcher.cpp
index d290f95..6e6bce0 100644
--- a/src/slave/containerizer/fetcher.cpp
+++ b/src/slave/containerizer/fetcher.cpp
@@ -34,7 +34,6 @@ using process::Future;
 using mesos::fetcher::FetcherInfo;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -328,5 +327,4 @@ void FetcherProcess::kill(const ContainerID& containerId)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/fetcher.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/fetcher.hpp b/src/slave/containerizer/fetcher.hpp
index 1db0eaf..bfd98db 100644
--- a/src/slave/containerizer/fetcher.hpp
+++ b/src/slave/containerizer/fetcher.hpp
@@ -33,7 +33,6 @@
 #include "slave/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declaration.
@@ -152,7 +151,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_FETCHER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolator.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolator.cpp b/src/slave/containerizer/isolator.cpp
index 90a47c4..bb4da46 100644
--- a/src/slave/containerizer/isolator.cpp
+++ b/src/slave/containerizer/isolator.cpp
@@ -26,7 +26,6 @@ using std::string;
 using std::list;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -104,5 +103,4 @@ Future<Nothing> Isolator::cleanup(const ContainerID& containerId)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolator.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolator.hpp b/src/slave/containerizer/isolator.hpp
index a27c3e9..2226fa2 100644
--- a/src/slave/containerizer/isolator.hpp
+++ b/src/slave/containerizer/isolator.hpp
@@ -35,7 +35,6 @@
 #include "slave/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declaration.
@@ -147,7 +146,6 @@ public:
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/constants.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/constants.hpp b/src/slave/containerizer/isolators/cgroups/constants.hpp
index e6df4a2..472edb2 100644
--- a/src/slave/containerizer/isolators/cgroups/constants.hpp
+++ b/src/slave/containerizer/isolators/cgroups/constants.hpp
@@ -23,7 +23,6 @@
 #include <stout/duration.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // CPU subsystem constants.
@@ -37,7 +36,6 @@ const Duration MIN_CPU_CFS_QUOTA = Milliseconds(1);
 const Bytes MIN_MEMORY = Megabytes(32);
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __CGROUPS_ISOLATOR_CONSTANTS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/cpushare.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/cpushare.cpp b/src/slave/containerizer/isolators/cgroups/cpushare.cpp
index 90aabb8..6554ca3 100644
--- a/src/slave/containerizer/isolators/cgroups/cpushare.cpp
+++ b/src/slave/containerizer/isolators/cgroups/cpushare.cpp
@@ -53,7 +53,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -535,5 +534,4 @@ Future<list<Nothing> > CgroupsCpushareIsolatorProcess::_cleanup(
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/cpushare.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/cpushare.hpp b/src/slave/containerizer/isolators/cgroups/cpushare.hpp
index 4ded0c4..bcfa76d 100644
--- a/src/slave/containerizer/isolators/cgroups/cpushare.hpp
+++ b/src/slave/containerizer/isolators/cgroups/cpushare.hpp
@@ -28,7 +28,6 @@
 #include "slave/containerizer/isolators/cgroups/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Use the Linux cpu cgroup controller for cpu isolation which uses the
@@ -106,7 +105,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __CPUSHARE_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/mem.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/mem.cpp b/src/slave/containerizer/isolators/cgroups/mem.cpp
index 711d66d..0bb4039 100644
--- a/src/slave/containerizer/isolators/cgroups/mem.cpp
+++ b/src/slave/containerizer/isolators/cgroups/mem.cpp
@@ -53,7 +53,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -585,5 +584,4 @@ void CgroupsMemIsolatorProcess::oom(const ContainerID& containerId)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/mem.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/mem.hpp b/src/slave/containerizer/isolators/cgroups/mem.hpp
index 2fa7555..735cefc 100644
--- a/src/slave/containerizer/isolators/cgroups/mem.hpp
+++ b/src/slave/containerizer/isolators/cgroups/mem.hpp
@@ -26,7 +26,6 @@
 #include "slave/containerizer/isolators/cgroups/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class CgroupsMemIsolatorProcess : public IsolatorProcess
@@ -112,7 +111,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MEM_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/perf_event.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/perf_event.cpp b/src/slave/containerizer/isolators/cgroups/perf_event.cpp
index 6f67164..f94eeae 100644
--- a/src/slave/containerizer/isolators/cgroups/perf_event.cpp
+++ b/src/slave/containerizer/isolators/cgroups/perf_event.cpp
@@ -58,7 +58,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 Try<Isolator*> CgroupsPerfEventIsolatorProcess::create(const Flags& flags)
@@ -446,5 +445,4 @@ void CgroupsPerfEventIsolatorProcess::_sample(
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/cgroups/perf_event.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/cgroups/perf_event.hpp b/src/slave/containerizer/isolators/cgroups/perf_event.hpp
index e511c3e..12d1b89 100644
--- a/src/slave/containerizer/isolators/cgroups/perf_event.hpp
+++ b/src/slave/containerizer/isolators/cgroups/perf_event.hpp
@@ -30,7 +30,6 @@
 #include "slave/containerizer/isolator.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class CgroupsPerfEventIsolatorProcess : public IsolatorProcess
@@ -113,7 +112,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __PERF_EVENT_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/filesystem/shared.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/filesystem/shared.cpp b/src/slave/containerizer/isolators/filesystem/shared.cpp
index 5c347af..85a5ade 100644
--- a/src/slave/containerizer/isolators/filesystem/shared.cpp
+++ b/src/slave/containerizer/isolators/filesystem/shared.cpp
@@ -27,7 +27,6 @@ using std::set;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 SharedFilesystemIsolatorProcess::SharedFilesystemIsolatorProcess(
@@ -260,5 +259,4 @@ Future<Nothing> SharedFilesystemIsolatorProcess::cleanup(
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/filesystem/shared.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/filesystem/shared.hpp b/src/slave/containerizer/isolators/filesystem/shared.hpp
index 727f63e..eeb722d 100644
--- a/src/slave/containerizer/isolators/filesystem/shared.hpp
+++ b/src/slave/containerizer/isolators/filesystem/shared.hpp
@@ -22,7 +22,6 @@
 #include "slave/containerizer/isolator.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // This isolator is to be used when all containers share the host's
@@ -70,7 +69,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SHARED_FILESYSTEM_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/namespaces/pid.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/namespaces/pid.cpp b/src/slave/containerizer/isolators/namespaces/pid.cpp
index fdd430e..0ad102d 100644
--- a/src/slave/containerizer/isolators/namespaces/pid.cpp
+++ b/src/slave/containerizer/isolators/namespaces/pid.cpp
@@ -39,7 +39,6 @@ using std::set;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // The root directory where we bind mount all the namespace handles.
@@ -260,5 +259,4 @@ Future<Nothing> NamespacesPidIsolatorProcess::cleanup(
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/namespaces/pid.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/namespaces/pid.hpp b/src/slave/containerizer/isolators/namespaces/pid.hpp
index 8da6ccc..fae909f 100644
--- a/src/slave/containerizer/isolators/namespaces/pid.hpp
+++ b/src/slave/containerizer/isolators/namespaces/pid.hpp
@@ -28,7 +28,6 @@
 #include <stout/result.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // This isolator itself does not specify the necessary clone() flags
@@ -82,7 +81,6 @@ public:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __NAMESPACES_PID_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/network/helper.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/network/helper.cpp b/src/slave/containerizer/isolators/network/helper.cpp
index e5fb99e..291cbdd 100644
--- a/src/slave/containerizer/isolators/network/helper.cpp
+++ b/src/slave/containerizer/isolators/network/helper.cpp
@@ -21,7 +21,7 @@
 
 #include "slave/containerizer/isolators/network/port_mapping.hpp"
 
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 
 int main(int argc, char** argv)

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/network/port_mapping.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/network/port_mapping.cpp b/src/slave/containerizer/isolators/network/port_mapping.cpp
index b484bbf..361e33b 100644
--- a/src/slave/containerizer/isolators/network/port_mapping.cpp
+++ b/src/slave/containerizer/isolators/network/port_mapping.cpp
@@ -72,7 +72,7 @@
 
 #include "slave/containerizer/isolators/network/port_mapping.hpp"
 
-using namespace mesos::internal;
+using namespace mesos;
 
 using namespace process;
 
@@ -95,7 +95,6 @@ using std::vector;
 using filter::ip::PortRange;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 const std::string VETH_PREFIX = "mesos";
@@ -2970,5 +2969,4 @@ vector<PortRange> getPortRanges(const IntervalSet<uint16_t>& ports)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/network/port_mapping.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/network/port_mapping.hpp b/src/slave/containerizer/isolators/network/port_mapping.hpp
index 90d19a9..1e4ed3d 100644
--- a/src/slave/containerizer/isolators/network/port_mapping.hpp
+++ b/src/slave/containerizer/isolators/network/port_mapping.hpp
@@ -48,7 +48,6 @@
 #include "slave/containerizer/isolator.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // The prefix this isolator uses for the virtual ethernet devices.
@@ -361,7 +360,6 @@ protected:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __PORT_MAPPING_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/posix.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/posix.hpp b/src/slave/containerizer/isolators/posix.hpp
index 7a667e3..1c0e963 100644
--- a/src/slave/containerizer/isolators/posix.hpp
+++ b/src/slave/containerizer/isolators/posix.hpp
@@ -30,7 +30,6 @@
 #include "usage/usage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // A basic IsolatorProcess that keeps track of the pid but doesn't do any
@@ -163,7 +162,7 @@ public:
 
     // Use 'mesos-usage' but only request 'cpus_' values.
     Try<ResourceStatistics> usage =
-      mesos::internal::usage(pids.get(containerId).get(), false, true);
+      mesos::usage(pids.get(containerId).get(), false, true);
     if (usage.isError()) {
       return process::Failure(usage.error());
     }
@@ -196,7 +195,7 @@ public:
 
     // Use 'mesos-usage' but only request 'mem_' values.
     Try<ResourceStatistics> usage =
-      mesos::internal::usage(pids.get(containerId).get(), true, false);
+      mesos::usage(pids.get(containerId).get(), true, false);
     if (usage.isError()) {
       return process::Failure(usage.error());
     }
@@ -209,7 +208,6 @@ private:
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __POSIX_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/posix/disk.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/posix/disk.cpp b/src/slave/containerizer/isolators/posix/disk.cpp
index 7d37afd..b2be552 100644
--- a/src/slave/containerizer/isolators/posix/disk.cpp
+++ b/src/slave/containerizer/isolators/posix/disk.cpp
@@ -51,7 +51,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 Try<Isolator*> PosixDiskIsolatorProcess::create(const Flags& flags)
@@ -500,5 +499,4 @@ Future<Bytes> DiskUsageCollector::usage(const string& path)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/isolators/posix/disk.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/isolators/posix/disk.hpp b/src/slave/containerizer/isolators/posix/disk.hpp
index cf4e143..5995329 100644
--- a/src/slave/containerizer/isolators/posix/disk.hpp
+++ b/src/slave/containerizer/isolators/posix/disk.hpp
@@ -30,7 +30,6 @@
 #include "slave/containerizer/isolator.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declarations.
@@ -140,7 +139,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __POSIX_DISK_ISOLATOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/launcher.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/launcher.cpp b/src/slave/containerizer/launcher.cpp
index 92c0657..f2267ad 100644
--- a/src/slave/containerizer/launcher.cpp
+++ b/src/slave/containerizer/launcher.cpp
@@ -35,7 +35,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using state::RunState;
@@ -181,5 +180,4 @@ Future<Nothing> _destroy(const Future<Option<int> >& future)
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/launcher.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/launcher.hpp b/src/slave/containerizer/launcher.hpp
index 18b3546..b6fab38 100644
--- a/src/slave/containerizer/launcher.hpp
+++ b/src/slave/containerizer/launcher.hpp
@@ -35,7 +35,6 @@
 #include "slave/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class Launcher
@@ -106,7 +105,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LAUNCHER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/linux_launcher.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/linux_launcher.cpp b/src/slave/containerizer/linux_launcher.cpp
index 10c1203..8417160 100644
--- a/src/slave/containerizer/linux_launcher.cpp
+++ b/src/slave/containerizer/linux_launcher.cpp
@@ -48,7 +48,6 @@ using std::string;
 using std::vector;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using state::RunState;
@@ -410,5 +409,4 @@ string LinuxLauncher::cgroup(const ContainerID& containerId)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/linux_launcher.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/linux_launcher.hpp b/src/slave/containerizer/linux_launcher.hpp
index 3d9794d..0d630fa 100644
--- a/src/slave/containerizer/linux_launcher.hpp
+++ b/src/slave/containerizer/linux_launcher.hpp
@@ -22,7 +22,6 @@
 #include "slave/containerizer/launcher.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Launcher for Linux systems with cgroups. Uses a freezer cgroup to
@@ -70,7 +69,6 @@ private:
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __LINUX_LAUNCHER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/mesos/containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/containerizer.cpp b/src/slave/containerizer/mesos/containerizer.cpp
index d712278..fa40d47 100644
--- a/src/slave/containerizer/mesos/containerizer.cpp
+++ b/src/slave/containerizer/mesos/containerizer.cpp
@@ -62,7 +62,6 @@ using std::vector;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using mesos::modules::ModuleManager;
@@ -1123,5 +1122,4 @@ Future<hashset<ContainerID>> MesosContainerizerProcess::containers()
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/mesos/containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/containerizer.hpp b/src/slave/containerizer/mesos/containerizer.hpp
index 569119f..b3aafe4 100644
--- a/src/slave/containerizer/mesos/containerizer.hpp
+++ b/src/slave/containerizer/mesos/containerizer.hpp
@@ -30,7 +30,6 @@
 #include "slave/containerizer/launcher.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declaration.
@@ -267,7 +266,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MESOS_CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/mesos/launch.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/launch.cpp b/src/slave/containerizer/mesos/launch.cpp
index 2f2d60e..a0ff1b7 100644
--- a/src/slave/containerizer/mesos/launch.cpp
+++ b/src/slave/containerizer/mesos/launch.cpp
@@ -39,7 +39,6 @@ using std::map;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 const string MesosContainerizerLaunch::NAME = "launch";
@@ -248,5 +247,4 @@ int MesosContainerizerLaunch::execute()
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/mesos/launch.hpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/launch.hpp b/src/slave/containerizer/mesos/launch.hpp
index 7c8b535..0176556 100644
--- a/src/slave/containerizer/mesos/launch.hpp
+++ b/src/slave/containerizer/mesos/launch.hpp
@@ -24,7 +24,6 @@
 #include <stout/subcommand.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class MesosContainerizerLaunch : public Subcommand
@@ -54,7 +53,6 @@ protected:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __MESOS_CONTAINERIZER_LAUNCH_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/containerizer/mesos/main.cpp
----------------------------------------------------------------------
diff --git a/src/slave/containerizer/mesos/main.cpp b/src/slave/containerizer/mesos/main.cpp
index 0e17931..136390d 100644
--- a/src/slave/containerizer/mesos/main.cpp
+++ b/src/slave/containerizer/mesos/main.cpp
@@ -21,7 +21,7 @@
 
 #include "slave/containerizer/mesos/launch.hpp"
 
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 
 int main(int argc, char** argv)

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/flags.hpp
----------------------------------------------------------------------
diff --git a/src/slave/flags.hpp b/src/slave/flags.hpp
index 53a6934..f603335 100644
--- a/src/slave/flags.hpp
+++ b/src/slave/flags.hpp
@@ -35,7 +35,6 @@
 #include "slave/constants.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class Flags : public logging::Flags
@@ -513,7 +512,6 @@ public:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_FLAGS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/gc.cpp
----------------------------------------------------------------------
diff --git a/src/slave/gc.cpp b/src/slave/gc.cpp
index 6042277..6060c18 100644
--- a/src/slave/gc.cpp
+++ b/src/slave/gc.cpp
@@ -37,7 +37,6 @@ using std::map;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
@@ -207,5 +206,4 @@ void GarbageCollector::prune(const Duration& d)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/gc.hpp
----------------------------------------------------------------------
diff --git a/src/slave/gc.hpp b/src/slave/gc.hpp
index 780f9c9..d9f9d7b 100644
--- a/src/slave/gc.hpp
+++ b/src/slave/gc.hpp
@@ -35,7 +35,6 @@
 #include <stout/try.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declarations.
@@ -131,7 +130,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_GC_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/graceful_shutdown.cpp
----------------------------------------------------------------------
diff --git a/src/slave/graceful_shutdown.cpp b/src/slave/graceful_shutdown.cpp
index 04d8f09..2ab58f7 100644
--- a/src/slave/graceful_shutdown.cpp
+++ b/src/slave/graceful_shutdown.cpp
@@ -24,7 +24,6 @@
 #include "slave/graceful_shutdown.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Calculates the shutdown grace period (aka shutdown timeout) so it
@@ -72,5 +71,4 @@ Duration getExecutorGracePeriod(const Duration& baseShutdownTimeout)
 
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/graceful_shutdown.hpp
----------------------------------------------------------------------
diff --git a/src/slave/graceful_shutdown.hpp b/src/slave/graceful_shutdown.hpp
index 59f5cfb..950329d 100644
--- a/src/slave/graceful_shutdown.hpp
+++ b/src/slave/graceful_shutdown.hpp
@@ -20,7 +20,6 @@
 #define __SLAVE_GRACEFUL_SHUTDOWN_HPP__
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Slave           Exec          Executor
@@ -62,7 +61,6 @@ Duration getExecGracePeriod(const Duration& baseShutdownTimeout);
 Duration getExecutorGracePeriod(const Duration& baseShutdownTimeout);
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_GRACEFUL_SHUTDOWN_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/http.cpp
----------------------------------------------------------------------
diff --git a/src/slave/http.cpp b/src/slave/http.cpp
index 0395d00..c9b5731 100644
--- a/src/slave/http.cpp
+++ b/src/slave/http.cpp
@@ -64,12 +64,11 @@ using std::vector;
 
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 
 // Pull in defnitions from common.
-using mesos::internal::model;
+using mesos::model;
 
 // Pull in the process definitions.
 using process::http::Response;
@@ -400,5 +399,4 @@ Future<Response> Slave::Http::state(const Request& request)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/main.cpp
----------------------------------------------------------------------
diff --git a/src/slave/main.cpp b/src/slave/main.cpp
index 42e46c5..173a1a3 100644
--- a/src/slave/main.cpp
+++ b/src/slave/main.cpp
@@ -43,8 +43,8 @@
 #include "slave/slave.hpp"
 #include "slave/status_update_manager.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
+using namespace mesos;
+using namespace mesos::slave;
 
 using mesos::modules::ModuleManager;
 using mesos::SlaveInfo;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/metrics.cpp
----------------------------------------------------------------------
diff --git a/src/slave/metrics.cpp b/src/slave/metrics.cpp
index c32b4d8..ee610b8 100644
--- a/src/slave/metrics.cpp
+++ b/src/slave/metrics.cpp
@@ -27,7 +27,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 Metrics::Metrics(const Slave& slave)
@@ -179,5 +178,4 @@ Metrics::~Metrics()
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/metrics.hpp
----------------------------------------------------------------------
diff --git a/src/slave/metrics.hpp b/src/slave/metrics.hpp
index 0390461..e2ce845 100644
--- a/src/slave/metrics.hpp
+++ b/src/slave/metrics.hpp
@@ -26,7 +26,6 @@
 
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 class Slave;
@@ -70,7 +69,6 @@ struct Metrics
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_METRICS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/monitor.cpp
----------------------------------------------------------------------
diff --git a/src/slave/monitor.cpp b/src/slave/monitor.cpp
index 398af01..c2c286c 100644
--- a/src/slave/monitor.cpp
+++ b/src/slave/monitor.cpp
@@ -47,7 +47,6 @@ using std::map;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using process::wait; // Necessary on some OS's to disambiguate.
@@ -308,5 +307,4 @@ Future<Nothing> ResourceMonitor::stop(
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/monitor.hpp
----------------------------------------------------------------------
diff --git a/src/slave/monitor.hpp b/src/slave/monitor.hpp
index f4ebafc..2cc42dc 100644
--- a/src/slave/monitor.hpp
+++ b/src/slave/monitor.hpp
@@ -41,7 +41,6 @@
 #include "common/type_utils.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declarations.
@@ -182,7 +181,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_MONITOR_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/paths.cpp
----------------------------------------------------------------------
diff --git a/src/slave/paths.cpp b/src/slave/paths.cpp
index 5fcfa2c..5102db5 100644
--- a/src/slave/paths.cpp
+++ b/src/slave/paths.cpp
@@ -38,7 +38,6 @@ using std::list;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 namespace paths {
 
@@ -429,5 +428,4 @@ string createSlaveDirectory(
 
 } // namespace paths {
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/paths.hpp
----------------------------------------------------------------------
diff --git a/src/slave/paths.hpp b/src/slave/paths.hpp
index 1618439..eba398c 100644
--- a/src/slave/paths.hpp
+++ b/src/slave/paths.hpp
@@ -25,7 +25,6 @@
 #include <mesos/mesos.hpp>
 
 namespace mesos {
-namespace internal {
 namespace slave {
 namespace paths {
 
@@ -263,7 +262,6 @@ std::string createSlaveDirectory(
 
 } // namespace paths {
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_PATHS_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/slave.cpp
----------------------------------------------------------------------
diff --git a/src/slave/slave.cpp b/src/slave/slave.cpp
index a8b2621..336e877 100644
--- a/src/slave/slave.cpp
+++ b/src/slave/slave.cpp
@@ -99,7 +99,6 @@ using process::Time;
 using process::UPID;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using namespace state;
@@ -4424,5 +4423,4 @@ std::ostream& operator << (std::ostream& stream, Executor::State state)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/slave.hpp
----------------------------------------------------------------------
diff --git a/src/slave/slave.hpp b/src/slave/slave.hpp
index 70bd8c1..9adee17 100644
--- a/src/slave/slave.hpp
+++ b/src/slave/slave.hpp
@@ -64,7 +64,6 @@
 #include "messages/messages.hpp"
 
 namespace mesos {
-namespace internal {
 
 class MasterDetector; // Forward declaration.
 
@@ -606,7 +605,6 @@ std::ostream& operator << (std::ostream& stream, Framework::State state);
 std::ostream& operator << (std::ostream& stream, Executor::State state);
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/state.cpp
----------------------------------------------------------------------
diff --git a/src/slave/state.cpp b/src/slave/state.cpp
index 72191ee..d0d7eba 100644
--- a/src/slave/state.cpp
+++ b/src/slave/state.cpp
@@ -19,7 +19,6 @@
 #include "slave/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 namespace state {
 
@@ -738,5 +737,4 @@ Try<ResourcesState> ResourcesState::recover(
 
 } // namespace state {
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/state.hpp
----------------------------------------------------------------------
diff --git a/src/slave/state.hpp b/src/slave/state.hpp
index f92808a..04084fc 100644
--- a/src/slave/state.hpp
+++ b/src/slave/state.hpp
@@ -43,7 +43,6 @@
 #include "process/pid.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 namespace state {
 
@@ -104,7 +103,7 @@ inline Try<Nothing> checkpoint(
   return checkpoint(path, messages);
 }
 
-}  // namespace internal {
+} // namespace internal {
 
 
 // Thin wrapper to checkpoint data to disk and perform the necessary
@@ -298,7 +297,6 @@ struct TaskState
 
 } // namespace state {
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __SLAVE_STATE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/status_update_manager.cpp
----------------------------------------------------------------------
diff --git a/src/slave/status_update_manager.cpp b/src/slave/status_update_manager.cpp
index fab8c22..5b0192b 100644
--- a/src/slave/status_update_manager.cpp
+++ b/src/slave/status_update_manager.cpp
@@ -50,7 +50,6 @@ using process::Timeout;
 using process::UPID;
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 using state::SlaveState;
@@ -634,5 +633,4 @@ void StatusUpdateManager::cleanup(const FrameworkID& frameworkId)
 }
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/slave/status_update_manager.hpp
----------------------------------------------------------------------
diff --git a/src/slave/status_update_manager.hpp b/src/slave/status_update_manager.hpp
index daab8e3..cc53a2a 100644
--- a/src/slave/status_update_manager.hpp
+++ b/src/slave/status_update_manager.hpp
@@ -50,7 +50,6 @@
 #include "slave/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace slave {
 
 // Forward declarations.
@@ -409,7 +408,6 @@ private:
 };
 
 } // namespace slave {
-} // namespace internal {
 } // namespace mesos {
 
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/in_memory.cpp
----------------------------------------------------------------------
diff --git a/src/state/in_memory.cpp b/src/state/in_memory.cpp
index ce04e47..6f33616 100644
--- a/src/state/in_memory.cpp
+++ b/src/state/in_memory.cpp
@@ -21,7 +21,6 @@ using namespace process;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 
@@ -112,5 +111,4 @@ Future<std::set<string> > InMemoryStorage::names()
 }
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/in_memory.hpp
----------------------------------------------------------------------
diff --git a/src/state/in_memory.hpp b/src/state/in_memory.hpp
index 2040618..fea2e10 100644
--- a/src/state/in_memory.hpp
+++ b/src/state/in_memory.hpp
@@ -14,7 +14,6 @@
 #include "state/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // Forward declaration.
@@ -38,7 +37,6 @@ private:
 };
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_IN_MEMORY_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/leveldb.cpp
----------------------------------------------------------------------
diff --git a/src/state/leveldb.cpp b/src/state/leveldb.cpp
index 4303df3..263a6b9 100644
--- a/src/state/leveldb.cpp
+++ b/src/state/leveldb.cpp
@@ -32,7 +32,6 @@ using namespace process;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 
@@ -294,5 +293,4 @@ Future<std::set<string> > LevelDBStorage::names()
 }
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/leveldb.hpp
----------------------------------------------------------------------
diff --git a/src/state/leveldb.hpp b/src/state/leveldb.hpp
index 53447c6..379316c 100644
--- a/src/state/leveldb.hpp
+++ b/src/state/leveldb.hpp
@@ -15,7 +15,6 @@
 #include "state/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // More forward declarations.
@@ -39,7 +38,6 @@ private:
 };
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_LEVELDB_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/log.cpp
----------------------------------------------------------------------
diff --git a/src/state/log.cpp b/src/state/log.cpp
index 326f3a7..6069d12 100644
--- a/src/state/log.cpp
+++ b/src/state/log.cpp
@@ -29,7 +29,7 @@
 
 #include "state/log.hpp"
 
-using namespace mesos::internal::log;
+using namespace mesos::log;
 using namespace process;
 
 // Note that we don't add 'using std::set' here because we need
@@ -38,7 +38,6 @@ using std::list;
 using std::string;
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // A storage implementation for State that uses the replicated
@@ -672,5 +671,4 @@ Future<std::set<string> > LogStorage::names()
 }
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/log.hpp
----------------------------------------------------------------------
diff --git a/src/state/log.hpp b/src/state/log.hpp
index a0ca4f8..1558dad 100644
--- a/src/state/log.hpp
+++ b/src/state/log.hpp
@@ -16,7 +16,6 @@
 #include "state/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // Forward declarations.
@@ -41,7 +40,6 @@ private:
 };
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_LOG_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/protobuf.hpp
----------------------------------------------------------------------
diff --git a/src/state/protobuf.hpp b/src/state/protobuf.hpp
index 12f9bfb..6f67c6a 100644
--- a/src/state/protobuf.hpp
+++ b/src/state/protobuf.hpp
@@ -36,7 +36,6 @@
 #include "state/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 namespace protobuf {
 
@@ -164,7 +163,6 @@ process::Future<bool> State::expunge(const Variable<T>& variable)
 
 } // namespace protobuf {
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_PROTOBUF_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/state.hpp
----------------------------------------------------------------------
diff --git a/src/state/state.hpp b/src/state/state.hpp
index 2c0bb20..878265d 100644
--- a/src/state/state.hpp
+++ b/src/state/state.hpp
@@ -37,7 +37,6 @@
 #include "state/storage.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // An abstraction of "state" (possibly between multiple distributed
@@ -195,7 +194,6 @@ inline process::Future<std::set<std::string> > State::names()
 }
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_STATE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/storage.hpp
----------------------------------------------------------------------
diff --git a/src/state/storage.hpp b/src/state/storage.hpp
index a36a93e..190c7a3 100644
--- a/src/state/storage.hpp
+++ b/src/state/storage.hpp
@@ -30,9 +30,10 @@
 #include "messages/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
+using namespace mesos::internal::state;
+
 class Storage
 {
 public:
@@ -54,7 +55,6 @@ public:
 };
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_STORAGE_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/zookeeper.cpp
----------------------------------------------------------------------
diff --git a/src/state/zookeeper.cpp b/src/state/zookeeper.cpp
index d355bd7..e570a9b 100644
--- a/src/state/zookeeper.cpp
+++ b/src/state/zookeeper.cpp
@@ -43,7 +43,6 @@ using std::vector;
 using zookeeper::Authentication;
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 
@@ -650,5 +649,4 @@ Future<std::set<string> > ZooKeeperStorage::names()
 }
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/state/zookeeper.hpp
----------------------------------------------------------------------
diff --git a/src/state/zookeeper.hpp b/src/state/zookeeper.hpp
index 1a8483d..9352a21 100644
--- a/src/state/zookeeper.hpp
+++ b/src/state/zookeeper.hpp
@@ -17,7 +17,6 @@
 #include "zookeeper/authentication.hpp"
 
 namespace mesos {
-namespace internal {
 namespace state {
 
 // Forward declarations.
@@ -47,7 +46,6 @@ private:
 
 
 } // namespace state {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __STATE_ZOOKEEPER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/attributes_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/attributes_tests.cpp b/src/tests/attributes_tests.cpp
index 240a8ca..138d543 100644
--- a/src/tests/attributes_tests.cpp
+++ b/src/tests/attributes_tests.cpp
@@ -24,7 +24,6 @@
 #include "common/attributes.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
 
 using std::string;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/authentication_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/authentication_tests.cpp b/src/tests/authentication_tests.cpp
index 5cf2da4..c594f3f 100644
--- a/src/tests/authentication_tests.cpp
+++ b/src/tests/authentication_tests.cpp
@@ -32,13 +32,12 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
 using namespace process;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
 using testing::_;
 using testing::Eq;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/authorization_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/authorization_tests.cpp b/src/tests/authorization_tests.cpp
index a8fa4cc..edae66d 100644
--- a/src/tests/authorization_tests.cpp
+++ b/src/tests/authorization_tests.cpp
@@ -25,8 +25,7 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/cgroups_isolator_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/cgroups_isolator_tests.cpp b/src/tests/cgroups_isolator_tests.cpp
index 2d9738f..9fbde33 100644
--- a/src/tests/cgroups_isolator_tests.cpp
+++ b/src/tests/cgroups_isolator_tests.cpp
@@ -30,8 +30,7 @@
 #include "tests/script.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 using std::map;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/cgroups_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/cgroups_tests.cpp b/src/tests/cgroups_tests.cpp
index 1eea57f..9d50a47 100644
--- a/src/tests/cgroups_tests.cpp
+++ b/src/tests/cgroups_tests.cpp
@@ -53,7 +53,7 @@
 
 #include "tests/mesos.hpp" // For TEST_CGROUPS_(HIERARCHY|ROOT).
 
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/cluster.hpp
----------------------------------------------------------------------
diff --git a/src/tests/cluster.hpp b/src/tests/cluster.hpp
index 90fda52..2ea4047 100644
--- a/src/tests/cluster.hpp
+++ b/src/tests/cluster.hpp
@@ -77,7 +77,6 @@
 #include "zookeeper/url.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 class Cluster
@@ -585,7 +584,6 @@ inline Try<Nothing> Cluster::Slaves::stop(
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_CLUSTER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/common/http_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/common/http_tests.cpp b/src/tests/common/http_tests.cpp
index f087b23..b030a78 100644
--- a/src/tests/common/http_tests.cpp
+++ b/src/tests/common/http_tests.cpp
@@ -34,7 +34,6 @@
 using std::vector;
 
 using namespace mesos;
-using namespace mesos::internal;
 
 // TODO(bmahler): Add tests for other JSON models.
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/composing_containerizer_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/composing_containerizer_tests.cpp b/src/tests/composing_containerizer_tests.cpp
index 5ab5a36..6bb49ea 100644
--- a/src/tests/composing_containerizer_tests.cpp
+++ b/src/tests/composing_containerizer_tests.cpp
@@ -34,9 +34,8 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/containerizer.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer.cpp b/src/tests/containerizer.cpp
index 26b87ac..8341c20 100644
--- a/src/tests/containerizer.cpp
+++ b/src/tests/containerizer.cpp
@@ -29,7 +29,6 @@ using testing::Return;
 using namespace process;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 
@@ -245,5 +244,4 @@ void TestContainerizer::setup()
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/containerizer.hpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer.hpp b/src/tests/containerizer.hpp
index 24b014f..f6fdb52 100644
--- a/src/tests/containerizer.hpp
+++ b/src/tests/containerizer.hpp
@@ -45,7 +45,6 @@
 #include "slave/state.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Forward declaration.
@@ -134,7 +133,6 @@ private:
 };
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TEST_CONTAINERIZER_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/containerizer_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/containerizer_tests.cpp b/src/tests/containerizer_tests.cpp
index cfe31a6..7300333 100644
--- a/src/tests/containerizer_tests.cpp
+++ b/src/tests/containerizer_tests.cpp
@@ -43,8 +43,7 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
+using namespace mesos::slave;
 
 using std::map;
 using std::string;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/cram_md5_authentication_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/cram_md5_authentication_tests.cpp b/src/tests/cram_md5_authentication_tests.cpp
index a356aa1..8b50413 100644
--- a/src/tests/cram_md5_authentication_tests.cpp
+++ b/src/tests/cram_md5_authentication_tests.cpp
@@ -37,7 +37,7 @@
 #include "tests/mesos.hpp"
 #include "tests/module.hpp"
 
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 
@@ -47,7 +47,6 @@ using testing::_;
 using testing::Eq;
 
 namespace mesos {
-namespace internal {
 namespace cram_md5 {
 
 template <typename T>
@@ -273,5 +272,4 @@ TYPED_TEST(CRAMMD5Authentication, AuthenticatorDestructionRace)
 }
 
 } // namespace cram_md5 {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/credentials_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/credentials_tests.cpp b/src/tests/credentials_tests.cpp
index 091b545..e39db9e 100644
--- a/src/tests/credentials_tests.cpp
+++ b/src/tests/credentials_tests.cpp
@@ -33,12 +33,11 @@ using std::string;
 using std::vector;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Slave;
 
 using process::PID;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/disk_quota_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/disk_quota_tests.cpp b/src/tests/disk_quota_tests.cpp
index 3239ed2..1d3aa0c 100644
--- a/src/tests/disk_quota_tests.cpp
+++ b/src/tests/disk_quota_tests.cpp
@@ -49,8 +49,7 @@
 using namespace process;
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using std::string;
 using std::vector;
@@ -58,12 +57,12 @@ using std::vector;
 using testing::_;
 using testing::Return;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::DiskUsageCollector;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::MesosContainerizer;
-using mesos::internal::slave::Slave;
+using mesos::slave::DiskUsageCollector;
+using mesos::slave::Fetcher;
+using mesos::slave::MesosContainerizer;
+using mesos::slave::Slave;
 
 
 class DiskUsageCollectorTest : public TemporaryDirectoryTest {};

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/docker_containerizer_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/docker_containerizer_tests.cpp b/src/tests/docker_containerizer_tests.cpp
index 2105ae2..8b212d4 100644
--- a/src/tests/docker_containerizer_tests.cpp
+++ b/src/tests/docker_containerizer_tests.cpp
@@ -42,19 +42,18 @@
 
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave::paths;
-using namespace mesos::internal::slave::state;
-using namespace mesos::internal::tests;
+using namespace mesos::slave::paths;
+using namespace mesos::slave::state;
+using namespace mesos::tests;
 
 using namespace process;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::DockerContainerizer;
-using mesos::internal::slave::DockerContainerizerProcess;
-using mesos::internal::slave::Fetcher;
-using mesos::internal::slave::Slave;
+using mesos::slave::DockerContainerizer;
+using mesos::slave::DockerContainerizerProcess;
+using mesos::slave::Fetcher;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::Message;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/docker_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/docker_tests.cpp b/src/tests/docker_tests.cpp
index ef05828..ae01a4e 100644
--- a/src/tests/docker_tests.cpp
+++ b/src/tests/docker_tests.cpp
@@ -35,8 +35,7 @@
 #include "tests/flags.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/environment.cpp
----------------------------------------------------------------------
diff --git a/src/tests/environment.cpp b/src/tests/environment.cpp
index e002363..0c2157b 100644
--- a/src/tests/environment.cpp
+++ b/src/tests/environment.cpp
@@ -64,7 +64,6 @@ using std::vector;
 using process::Owned;
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Storage for the global environment instance.
@@ -441,5 +440,4 @@ Try<string> Environment::mkdtemp()
 }
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/environment.hpp
----------------------------------------------------------------------
diff --git a/src/tests/environment.hpp b/src/tests/environment.hpp
index 9cf14bc..5779528 100644
--- a/src/tests/environment.hpp
+++ b/src/tests/environment.hpp
@@ -29,7 +29,6 @@
 #include "tests/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Used to set up and manage the test environment.
@@ -60,7 +59,6 @@ private:
 extern Environment* environment;
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {
 
 #endif // __TESTS_ENVIRONMENT_HPP__

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/exception_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/exception_tests.cpp b/src/tests/exception_tests.cpp
index 13e6d2d..7a41770 100644
--- a/src/tests/exception_tests.cpp
+++ b/src/tests/exception_tests.cpp
@@ -35,12 +35,11 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Future;
 using process::PID;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/external_containerizer_test.cpp
----------------------------------------------------------------------
diff --git a/src/tests/external_containerizer_test.cpp b/src/tests/external_containerizer_test.cpp
index 45cdeb5..d6c4437 100644
--- a/src/tests/external_containerizer_test.cpp
+++ b/src/tests/external_containerizer_test.cpp
@@ -43,14 +43,13 @@
 #include "tests/flags.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos::tests;
 
 using namespace process;
 
-using mesos::internal::master::Master;
-using mesos::internal::slave::Containerizer;
-using mesos::internal::slave::Slave;
+using mesos::master::Master;
+using mesos::slave::Containerizer;
+using mesos::slave::Slave;
 
 using std::string;
 using std::vector;

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/fault_tolerance_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/fault_tolerance_tests.cpp b/src/tests/fault_tolerance_tests.cpp
index f927d4a..c811873 100644
--- a/src/tests/fault_tolerance_tests.cpp
+++ b/src/tests/fault_tolerance_tests.cpp
@@ -49,13 +49,12 @@
 #include "tests/mesos.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::protobuf;
-using namespace mesos::internal::tests;
+using namespace mesos::protobuf;
+using namespace mesos::tests;
 
-using mesos::internal::master::Master;
+using mesos::master::Master;
 
-using mesos::internal::slave::Slave;
+using mesos::slave::Slave;
 
 using process::Clock;
 using process::Future;
@@ -805,7 +804,7 @@ TEST_F(FaultToleranceTest, SchedulerFailoverRetriedReregistration)
   AWAIT_READY(reregistrationMessage);
 
   // Trigger the re-registration retry.
-  Clock::advance(internal::scheduler::REGISTRATION_BACKOFF_FACTOR);
+  Clock::advance(scheduler::REGISTRATION_BACKOFF_FACTOR);
 
   AWAIT_READY(sched2Registered);
 
@@ -859,7 +858,7 @@ TEST_F(FaultToleranceTest, FrameworkReliableRegistration)
   AWAIT_READY(frameworkRegisteredMessage);
 
   Clock::pause();
-  Clock::advance(internal::scheduler::REGISTRATION_BACKOFF_FACTOR);
+  Clock::advance(scheduler::REGISTRATION_BACKOFF_FACTOR);
 
   AWAIT_READY(registered); // Ensures registered message is received.
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/fetcher_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/fetcher_tests.cpp b/src/tests/fetcher_tests.cpp
index 8c0b075..d7266f5 100644
--- a/src/tests/fetcher_tests.cpp
+++ b/src/tests/fetcher_tests.cpp
@@ -47,9 +47,8 @@
 #include "tests/utils.hpp"
 
 using namespace mesos;
-using namespace mesos::internal;
-using namespace mesos::internal::slave;
-using namespace mesos::internal::tests;
+using namespace mesos::slave;
+using namespace mesos::tests;
 
 using namespace process;
 using process::Subprocess;
@@ -339,7 +338,7 @@ TEST_F(FetcherTest, FileURI)
 
   Try<Subprocess> fetcherSubprocess =
     process::subprocess(
-      path::join(mesos::internal::tests::flags.build_dir, "src/mesos-fetcher"),
+      path::join(mesos::tests::flags.build_dir, "src/mesos-fetcher"),
       environment);
 
   ASSERT_SOME(fetcherSubprocess);
@@ -375,7 +374,7 @@ TEST_F(FetcherTest, FilePath)
 
   Try<Subprocess> fetcherSubprocess =
     process::subprocess(
-      path::join(mesos::internal::tests::flags.build_dir, "src/mesos-fetcher"),
+      path::join(mesos::tests::flags.build_dir, "src/mesos-fetcher"),
       environment);
 
   ASSERT_SOME(fetcherSubprocess);
@@ -428,7 +427,7 @@ TEST_F(FetcherTest, OSNetUriTest)
 
   Try<Subprocess> fetcherSubprocess =
     process::subprocess(
-      path::join(mesos::internal::tests::flags.build_dir, "src/mesos-fetcher"),
+      path::join(mesos::tests::flags.build_dir, "src/mesos-fetcher"),
       environment);
 
   ASSERT_SOME(fetcherSubprocess);
@@ -464,7 +463,7 @@ TEST_F(FetcherTest, FileLocalhostURI)
 
   Try<Subprocess> fetcherSubprocess =
     process::subprocess(
-      path::join(mesos::internal::tests::flags.build_dir, "src/mesos-fetcher"),
+      path::join(mesos::tests::flags.build_dir, "src/mesos-fetcher"),
       environment);
 
   ASSERT_SOME(fetcherSubprocess);

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/files_tests.cpp
----------------------------------------------------------------------
diff --git a/src/tests/files_tests.cpp b/src/tests/files_tests.cpp
index 9ad6db5..2e16665 100644
--- a/src/tests/files_tests.cpp
+++ b/src/tests/files_tests.cpp
@@ -35,8 +35,8 @@
 
 #include "tests/utils.hpp"
 
-using namespace mesos::internal;
-using namespace mesos::internal::tests;
+using namespace mesos;
+using namespace mesos::tests;
 
 using process::Future;
 

http://git-wip-us.apache.org/repos/asf/mesos/blob/7c418577/src/tests/flags.cpp
----------------------------------------------------------------------
diff --git a/src/tests/flags.cpp b/src/tests/flags.cpp
index 98b780f..693c2bd 100644
--- a/src/tests/flags.cpp
+++ b/src/tests/flags.cpp
@@ -19,12 +19,10 @@
 #include "tests/flags.hpp"
 
 namespace mesos {
-namespace internal {
 namespace tests {
 
 // Storage for the flags.
 Flags flags;
 
 } // namespace tests {
-} // namespace internal {
 } // namespace mesos {