You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by jb...@apache.org on 2018/04/24 18:34:08 UTC

[geode-native] branch develop updated: GEODE-5120: Move DistributedSystem.hpp internal.

This is an automated email from the ASF dual-hosted git repository.

jbarrett pushed a commit to branch develop
in repository https://gitbox.apache.org/repos/asf/geode-native.git


The following commit(s) were added to refs/heads/develop by this push:
     new 5ece73f  GEODE-5120: Move DistributedSystem.hpp internal.
5ece73f is described below

commit 5ece73f40dc2f71c27d0ba13e415786fc0e2bc1f
Author: Jacob Barrett <jb...@pivotal.io>
AuthorDate: Tue Apr 24 18:31:10 2018 +0000

    GEODE-5120: Move DistributedSystem.hpp internal.
---
 clicache/integration-test/ThinClientPdxTests.cs    |  2 +-
 clicache/src/DistributedSystem.hpp                 |  2 +-
 cppcache/include/geode/AuthenticatedView.hpp       |  1 -
 cppcache/include/geode/CacheFactory.hpp            |  1 -
 cppcache/src/AuthenticatedView.cpp                 |  1 -
 cppcache/src/Cache.cpp                             |  1 -
 cppcache/src/CacheConfig.hpp                       | 15 +++------
 cppcache/src/CacheImpl.hpp                         |  2 +-
 cppcache/src/ClientProxyMembershipID.cpp           | 12 ++++---
 cppcache/src/CqService.cpp                         | 37 ++++++++++++----------
 cppcache/src/CqService.hpp                         | 21 ++++++------
 cppcache/src/DistributedSystem.cpp                 |  2 +-
 .../{include/geode => src}/DistributedSystem.hpp   |  6 ++--
 cppcache/src/DistributedSystemImpl.hpp             | 27 +++++++++-------
 cppcache/src/EvictionController.cpp                |  5 +--
 cppcache/src/ExpiryTaskManager.cpp                 |  3 +-
 cppcache/src/RegionAttributesFactory.cpp           |  2 +-
 cppcache/src/TcpConn.cpp                           |  2 +-
 cppcache/src/TcpSslConn.cpp                        |  4 ++-
 cppcache/src/TcrConnection.cpp                     |  1 -
 cppcache/src/TcrMessage.cpp                        |  2 +-
 cppcache/src/ThreadPool.cpp                        | 12 +++----
 cppcache/src/Utils.hpp                             |  2 +-
 cppcache/src/statistics/HostStatSampler.cpp        | 11 +++----
 24 files changed, 89 insertions(+), 85 deletions(-)

diff --git a/clicache/integration-test/ThinClientPdxTests.cs b/clicache/integration-test/ThinClientPdxTests.cs
index bac8e6d..3039cc5 100755
--- a/clicache/integration-test/ThinClientPdxTests.cs
+++ b/clicache/integration-test/ThinClientPdxTests.cs
@@ -4953,7 +4953,7 @@ namespace Apache.Geode.Client.UnitTests
          object ret = region0[2];
          Assert.Fail("Expected exception.");
        }
-       catch (Exception ex) {
+       catch (Exception) {
          // Expected
        }
      }
diff --git a/clicache/src/DistributedSystem.hpp b/clicache/src/DistributedSystem.hpp
index 7e0e27c..2ad4110 100644
--- a/clicache/src/DistributedSystem.hpp
+++ b/clicache/src/DistributedSystem.hpp
@@ -20,7 +20,7 @@
 
 #include "geode_defs.hpp"
 #include "begin_native.hpp"
-#include <geode/DistributedSystem.hpp>
+#include "DistributedSystem.hpp"
 #include "end_native.hpp"
 
 #include "native_conditional_unique_ptr.hpp"
diff --git a/cppcache/include/geode/AuthenticatedView.hpp b/cppcache/include/geode/AuthenticatedView.hpp
index c9c522e..180399f 100644
--- a/cppcache/include/geode/AuthenticatedView.hpp
+++ b/cppcache/include/geode/AuthenticatedView.hpp
@@ -22,7 +22,6 @@
 
 #include <geode/internal/geode_globals.hpp>
 #include <geode/Region.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/QueryService.hpp>
 #include <geode/PoolFactory.hpp>
 #include <geode/RegionService.hpp>
diff --git a/cppcache/include/geode/CacheFactory.hpp b/cppcache/include/geode/CacheFactory.hpp
index dc60e3f..aca9c24 100644
--- a/cppcache/include/geode/CacheFactory.hpp
+++ b/cppcache/include/geode/CacheFactory.hpp
@@ -23,7 +23,6 @@
 #include <string>
 
 #include "internal/geode_globals.hpp"
-#include "DistributedSystem.hpp"
 #include "Cache.hpp"
 #include "CacheAttributes.hpp"
 #include "PoolFactory.hpp"
diff --git a/cppcache/src/AuthenticatedView.cpp b/cppcache/src/AuthenticatedView.cpp
index 5ab2161..56c9ed3 100644
--- a/cppcache/src/AuthenticatedView.cpp
+++ b/cppcache/src/AuthenticatedView.cpp
@@ -19,7 +19,6 @@
 #include <memory>
 
 #include <geode/internal/geode_globals.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/Cache.hpp>
 #include <geode/FunctionService.hpp>
 #include <geode/AuthenticatedView.hpp>
diff --git a/cppcache/src/Cache.cpp b/cppcache/src/Cache.cpp
index 75f879d..83baeba 100644
--- a/cppcache/src/Cache.cpp
+++ b/cppcache/src/Cache.cpp
@@ -20,7 +20,6 @@
 #include <geode/internal/geode_globals.hpp>
 #include <geode/FunctionService.hpp>
 #include <geode/PoolManager.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/Cache.hpp>
 #include <geode/RegionFactory.hpp>
 
diff --git a/cppcache/src/CacheConfig.hpp b/cppcache/src/CacheConfig.hpp
index 993e262..51010d3 100644
--- a/cppcache/src/CacheConfig.hpp
+++ b/cppcache/src/CacheConfig.hpp
@@ -20,23 +20,18 @@
  * limitations under the License.
  */
 
-/**
- * @file
- */
-// CacheConfig.h: interface for the CacheConfig class.
-//
-//////////////////////////////////////////////////////////////////////
-
 #if defined(_MSC_VER) && _MSC_VER > 1000
 #pragma warning(disable : 4786)
 #endif  // _MSC_VER > 1000
 
-#include <geode/internal/geode_globals.hpp>
 #include <string>
 #include <map>
-#include "RegionConfig.hpp"
+
+#include <geode/internal/geode_globals.hpp>
 #include <geode/ExceptionTypes.hpp>
-#include <geode/DistributedSystem.hpp>
+
+#include "RegionConfig.hpp"
+#include "DistributedSystem.hpp"
 
 //
 // Sneaky structure forward decl;
diff --git a/cppcache/src/CacheImpl.hpp b/cppcache/src/CacheImpl.hpp
index aab924c..c5fdd5d 100644
--- a/cppcache/src/CacheImpl.hpp
+++ b/cppcache/src/CacheImpl.hpp
@@ -31,9 +31,9 @@
 #include <geode/internal/geode_globals.hpp>
 #include <geode/Cache.hpp>
 #include <geode/CacheAttributes.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/TypeRegistry.hpp>
 
+#include "DistributedSystem.hpp"
 #include "MapWithLock.hpp"
 #include "Condition.hpp"
 #include "TcrConnectionManager.hpp"
diff --git a/cppcache/src/ClientProxyMembershipID.cpp b/cppcache/src/ClientProxyMembershipID.cpp
index 64e20e0..5ab2492 100644
--- a/cppcache/src/ClientProxyMembershipID.cpp
+++ b/cppcache/src/ClientProxyMembershipID.cpp
@@ -16,16 +16,20 @@
  */
 
 #include "ClientProxyMembershipID.hpp"
+
 #include <ctime>
+#include <string>
+#include <memory>
+
 #include <ace/OS.h>
-#include <geode/DistributedSystem.hpp>
+
 #include <geode/GeodeTypeIds.hpp>
-#include "GeodeTypeIdsImpl.hpp"
 #include <geode/CacheableBuiltins.hpp>
+
+#include "GeodeTypeIdsImpl.hpp"
+#include "DistributedSystem.hpp"
 #include "DataOutputInternal.hpp"
 #include "Version.hpp"
-#include <string>
-#include <memory>
 
 #define ADDRSIZE 4
 #define DCPORT 12334
diff --git a/cppcache/src/CqService.cpp b/cppcache/src/CqService.cpp
index f0c791f..5b67e9e 100644
--- a/cppcache/src/CqService.cpp
+++ b/cppcache/src/CqService.cpp
@@ -19,10 +19,10 @@
 
 #include <geode/CqStatusListener.hpp>
 #include <geode/CqServiceStatistics.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
 #include <geode/ExceptionTypes.hpp>
 
+#include "DistributedSystem.hpp"
 #include "CqService.hpp"
 #include "ReadWriteLock.hpp"
 #include "CqQueryImpl.hpp"
@@ -126,16 +126,17 @@ std::shared_ptr<CqQuery> CqService::newCq(
         ("CQ with the given name already exists. CqName : " + cqName).c_str());
   }
 
-std::shared_ptr<UserAttributes> ua = nullptr;
-if (m_tccdm != nullptr && m_tccdm->isMultiUserMode()) {
-  ua = TSSUserAttributesWrapper::s_geodeTSSUserAttributes->getUserAttributes();
-}
+  std::shared_ptr<UserAttributes> ua = nullptr;
+  if (m_tccdm != nullptr && m_tccdm->isMultiUserMode()) {
+    ua =
+        TSSUserAttributesWrapper::s_geodeTSSUserAttributes->getUserAttributes();
+  }
 
-auto cQuery = std::make_shared<CqQueryImpl>(shared_from_this(), cqName,
-                                            queryString, cqAttributes,
-                                            m_statisticsFactory, isDurable, ua);
-cQuery->initCq();
-return cQuery;
+  auto cQuery = std::make_shared<CqQueryImpl>(
+      shared_from_this(), cqName, queryString, cqAttributes,
+      m_statisticsFactory, isDurable, ua);
+  cQuery->initCq();
+  return cQuery;
 }
 
 /**
@@ -169,7 +170,8 @@ void CqService::removeCq(const std::string& cqName) {
 /**
  * Retrieve a CqQuery by name.
  * @return the CqQuery or null if not found
- */ std::shared_ptr<CqQuery> CqService::getCq(const std::string& cqName) {
+ */
+std::shared_ptr<CqQuery> CqService::getCq(const std::string& cqName) {
   MapOfRegionGuard guard(m_cqQueryMap->mutex());
   std::shared_ptr<CqQuery> tmp;
   if (0 != m_cqQueryMap->find(cqName, tmp)) {
@@ -347,7 +349,10 @@ void CqService::closeCqs(query_container_type& cqs) {
 /**
  * Get statistics information for all CQs
  * @return the CqServiceStatistics
- */ std::shared_ptr<CqServiceStatistics> CqService::getCqServiceStatistics() { return m_stats; }
+ */
+std::shared_ptr<CqServiceStatistics> CqService::getCqServiceStatistics() {
+  return m_stats;
+}
 
 /**
  * Close the CQ Service after cleanup if any.
@@ -562,7 +567,8 @@ CqOperation CqService::getOperation(int eventType) {
  *
  * @return List of names of registered durable CQs, empty list if no durable
  * cqs.
- */ std::shared_ptr<CacheableArrayList> CqService::getAllDurableCqsFromServer() {
+ */
+std::shared_ptr<CacheableArrayList> CqService::getAllDurableCqsFromServer() {
   TcrMessageGetDurableCqs msg(m_tccdm->getConnectionManager()
                                   .getCacheImpl()
                                   ->getCache()
@@ -590,15 +596,14 @@ CqOperation CqService::getOperation(int eventType) {
     if (err == GF_CACHESERVER_EXCEPTION) {
       std::stringstream message;
       message << "CqService::getAllDurableCqsFromServer: exception "
-              << "at the server side: "
-              << reply.getException();
+              << "at the server side: " << reply.getException();
       throw CqQueryException(message.str());
     } else {
       GfErrTypeToException("CqService::getAllDurableCqsFromServer", err);
     }
   }
 
- auto tmpRes = resultCollector->getResults();
+  auto tmpRes = resultCollector->getResults();
   delete resultCollector;
   return tmpRes;
 }
diff --git a/cppcache/src/CqService.hpp b/cppcache/src/CqService.hpp
index 28f70bf..7268c4d 100644
--- a/cppcache/src/CqService.hpp
+++ b/cppcache/src/CqService.hpp
@@ -20,27 +20,29 @@
 #ifndef GEODE_CQSERVICE_H_
 #define GEODE_CQSERVICE_H_
 
-#include <geode/internal/geode_globals.hpp>
-#include "TcrMessage.hpp"
-#include "Queue.hpp"
+#include <map>
+#include <string>
+
 #include <ace/ACE.h>
 #include <ace/Condition_Recursive_Thread_Mutex.h>
 #include <ace/Time_Value.h>
 #include <ace/Guard_T.h>
 #include <ace/Recursive_Thread_Mutex.h>
 #include <ace/Semaphore.h>
+#include <ace/Task.h>
+
 #include <geode/CacheableKey.hpp>
 #include <geode/CqOperation.hpp>
 #include <geode/CqQuery.hpp>
+#include <geode/internal/geode_globals.hpp>
+
+#include "TcrMessage.hpp"
+#include "Queue.hpp"
 #include "MapWithLock.hpp"
-#include <geode/DistributedSystem.hpp>
-#include <map>
-#include <string>
+#include "DistributedSystem.hpp"
 #include "Queue.hpp"
-#include <ace/Task.h>
 #include "ThinClientBaseDM.hpp"
 #include "CqServiceVsdStats.hpp"
-
 #include "NonCopyable.hpp"
 
 /**
@@ -85,7 +87,8 @@ class APACHE_GEODE_EXPORT CqService
   /**
    * Constructor.
    */
-  CqService(ThinClientBaseDM* tccdm, statistics::StatisticsFactory* statisticsFactory);
+  CqService(ThinClientBaseDM* tccdm,
+            statistics::StatisticsFactory* statisticsFactory);
   ThinClientBaseDM* getDM() { return m_tccdm; }
 
   void receiveNotification(TcrMessage* msg);
diff --git a/cppcache/src/DistributedSystem.cpp b/cppcache/src/DistributedSystem.cpp
index 1848507..f013cde 100644
--- a/cppcache/src/DistributedSystem.cpp
+++ b/cppcache/src/DistributedSystem.cpp
@@ -20,11 +20,11 @@
 #include <ace/Recursive_Thread_Mutex.h>
 
 #include <geode/internal/geode_globals.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/CacheFactory.hpp>
 #include <geode/SystemProperties.hpp>
 #include <geode/DataOutput.hpp>
 
+#include "DistributedSystem.hpp"
 #include "CppCacheLibrary.hpp"
 #include "Utils.hpp"
 #include "util/Log.hpp"
diff --git a/cppcache/include/geode/DistributedSystem.hpp b/cppcache/src/DistributedSystem.hpp
similarity index 96%
rename from cppcache/include/geode/DistributedSystem.hpp
rename to cppcache/src/DistributedSystem.hpp
index 7413ecc..0ccab18 100644
--- a/cppcache/include/geode/DistributedSystem.hpp
+++ b/cppcache/src/DistributedSystem.hpp
@@ -25,9 +25,9 @@
  */
 #include <memory>
 
-#include "internal/geode_globals.hpp"
-#include "ExceptionTypes.hpp"
-#include "Properties.hpp"
+#include <geode/internal/geode_globals.hpp>
+#include <geode/ExceptionTypes.hpp>
+#include <geode/Properties.hpp>
 
 namespace apache {
 namespace geode {
diff --git a/cppcache/src/DistributedSystemImpl.hpp b/cppcache/src/DistributedSystemImpl.hpp
index 8c03781..ba1996c 100644
--- a/cppcache/src/DistributedSystemImpl.hpp
+++ b/cppcache/src/DistributedSystemImpl.hpp
@@ -1,8 +1,3 @@
-#pragma once
-
-#ifndef GEODE_DISTRIBUTEDSYSTEMIMPL_H_
-#define GEODE_DISTRIBUTEDSYSTEMIMPL_H_
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
@@ -20,21 +15,29 @@
  * limitations under the License.
  */
 
+#pragma once
+
+#ifndef GEODE_DISTRIBUTEDSYSTEMIMPL_H_
+#define GEODE_DISTRIBUTEDSYSTEMIMPL_H_
+
 /**
  * @file
  */
 
-#include <geode/internal/geode_globals.hpp>
 #include <memory>
-#include "ace/Recursive_Thread_Mutex.h"
-#include "ace/Guard_T.h"
-#include "ace/OS.h"
-#include <geode/DistributedSystem.hpp>
-#include "DiffieHellman.hpp"
-#include "statistics/StatisticsManager.hpp"
 #include <string>
 #include <map>
 
+#include <ace/Recursive_Thread_Mutex.h>
+#include <ace/Guard_T.h>
+#include <ace/OS.h>
+
+#include <geode/internal/geode_globals.hpp>
+
+#include "DistributedSystem.hpp"
+#include "DiffieHellman.hpp"
+#include "statistics/StatisticsManager.hpp"
+
 #ifdef __linux
 #include <sys/prctl.h>
 #endif
diff --git a/cppcache/src/EvictionController.cpp b/cppcache/src/EvictionController.cpp
index e6b3278..7fe993c 100644
--- a/cppcache/src/EvictionController.cpp
+++ b/cppcache/src/EvictionController.cpp
@@ -15,13 +15,14 @@
  * limitations under the License.
  */
 
+#include <string>
+
 #include "EvictionController.hpp"
 #include "CacheImpl.hpp"
 #include "CacheRegionHelper.hpp"
 #include "RegionInternal.hpp"
-#include <geode/DistributedSystem.hpp>
+#include "DistributedSystem.hpp"
 #include "ReadWriteLock.hpp"
-#include <string>
 
 namespace apache {
 namespace geode {
diff --git a/cppcache/src/ExpiryTaskManager.cpp b/cppcache/src/ExpiryTaskManager.cpp
index ca7b10f..0176f18 100644
--- a/cppcache/src/ExpiryTaskManager.cpp
+++ b/cppcache/src/ExpiryTaskManager.cpp
@@ -14,10 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 #include "config.h"
 #include "ExpiryTaskManager.hpp"
 #include "util/Log.hpp"
-#include <geode/DistributedSystem.hpp>
+#include "DistributedSystem.hpp"
 #include "Assert.hpp"
 #include "DistributedSystemImpl.hpp"
 
diff --git a/cppcache/src/RegionAttributesFactory.cpp b/cppcache/src/RegionAttributesFactory.cpp
index 0cc5436..96cef04 100644
--- a/cppcache/src/RegionAttributesFactory.cpp
+++ b/cppcache/src/RegionAttributesFactory.cpp
@@ -20,10 +20,10 @@
 
 #include <geode/Cache.hpp>
 #include <geode/ExpirationAttributes.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/Pool.hpp>
 #include <geode/PoolManager.hpp>
 
+#include "DistributedSystem.hpp"
 #include "Utils.hpp"
 
 namespace apache {
diff --git a/cppcache/src/TcpConn.cpp b/cppcache/src/TcpConn.cpp
index e87f4f1..254d333 100644
--- a/cppcache/src/TcpConn.cpp
+++ b/cppcache/src/TcpConn.cpp
@@ -23,10 +23,10 @@
 #include <ace/SOCK_Acceptor.h>
 #include <ace/OS.h>
 
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
 #include <geode/internal/chrono/duration.hpp>
 
+#include "DistributedSystem.hpp"
 #include "TcpConn.hpp"
 #include "CacheImpl.hpp"
 #include "util/Log.hpp"
diff --git a/cppcache/src/TcpSslConn.cpp b/cppcache/src/TcpSslConn.cpp
index f72c35b..99f6732 100644
--- a/cppcache/src/TcpSslConn.cpp
+++ b/cppcache/src/TcpSslConn.cpp
@@ -14,10 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 #include "TcpSslConn.hpp"
 
 #include <geode/SystemProperties.hpp>
-#include <geode/DistributedSystem.hpp>
+
+#include "DistributedSystem.hpp"
 #include "CacheImpl.hpp"
 
 namespace apache {
diff --git a/cppcache/src/TcrConnection.cpp b/cppcache/src/TcrConnection.cpp
index e5f5da3..473c376 100644
--- a/cppcache/src/TcrConnection.cpp
+++ b/cppcache/src/TcrConnection.cpp
@@ -20,7 +20,6 @@
 #include <ace/INET_Addr.h>
 #include <ace/OS.h>
 
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
 #include <geode/AuthInitialize.hpp>
 
diff --git a/cppcache/src/TcrMessage.cpp b/cppcache/src/TcrMessage.cpp
index 2bfbaaa..d5314e7 100644
--- a/cppcache/src/TcrMessage.cpp
+++ b/cppcache/src/TcrMessage.cpp
@@ -16,10 +16,10 @@
  */
 
 #include <geode/CacheableBuiltins.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
 #include <geode/CacheableObjectArray.hpp>
 
+#include "DistributedSystem.hpp"
 #include "TcrMessage.hpp"
 #include "Assert.hpp"
 #include "TcrConnection.hpp"
diff --git a/cppcache/src/ThreadPool.cpp b/cppcache/src/ThreadPool.cpp
index ecca25d..b75ead7 100644
--- a/cppcache/src/ThreadPool.cpp
+++ b/cppcache/src/ThreadPool.cpp
@@ -14,18 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-/*
- * ThreadPool.cpp
- *
- *  Created on: 16-Mar-2010
- *      Author: ankurs
- */
 
-#include "ThreadPool.hpp"
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
+
+#include "ThreadPool.hpp"
+#include "DistributedSystem.hpp"
 #include "DistributedSystemImpl.hpp"
 #include "CacheImpl.hpp"
+
 using namespace apache::geode::client;
 
 ThreadPoolWorker::ThreadPoolWorker(IThreadPool* manager)
diff --git a/cppcache/src/Utils.hpp b/cppcache/src/Utils.hpp
index 270b3de..453e047 100644
--- a/cppcache/src/Utils.hpp
+++ b/cppcache/src/Utils.hpp
@@ -40,8 +40,8 @@
 #include <geode/CacheableString.hpp>
 #include <geode/DataOutput.hpp>
 #include <geode/SystemProperties.hpp>
-#include <geode/DistributedSystem.hpp>
 
+#include "DistributedSystem.hpp"
 #include "statistics/Statistics.hpp"
 #include "util/Log.hpp"
 #include "Assert.hpp"
diff --git a/cppcache/src/statistics/HostStatSampler.cpp b/cppcache/src/statistics/HostStatSampler.cpp
index 022382e..8f3e75e 100644
--- a/cppcache/src/statistics/HostStatSampler.cpp
+++ b/cppcache/src/statistics/HostStatSampler.cpp
@@ -30,12 +30,12 @@
 #include <ace/OS_NS_sys_stat.h>
 
 #include <geode/internal/geode_globals.hpp>
-#include <geode/DistributedSystem.hpp>
 #include <geode/SystemProperties.hpp>
 
 #include "HostStatSampler.hpp"
 #include "StatArchiveWriter.hpp"
 #include "GeodeStatisticsFactory.hpp"
+#include "../DistributedSystem.hpp"
 #include "../util/Log.hpp"
 #include "../ClientHealthStats.hpp"
 #include "../ClientProxyMembershipID.hpp"
@@ -118,14 +118,14 @@ int comparator(const dirent** d1, const dirent** d2) {
   }
 }
 
-}
+}  // namespace
 
 namespace apache {
 namespace geode {
 namespace statistics {
 
-using std::chrono::high_resolution_clock;
 using std::chrono::duration_cast;
+using std::chrono::high_resolution_clock;
 using std::chrono::milliseconds;
 using std::chrono::nanoseconds;
 
@@ -512,10 +512,9 @@ void HostStatSampler::initSpecialStats() {
   // After Special categories are decided initialize them here
 }
 
-void HostStatSampler::sampleSpecialStats() {  }
+void HostStatSampler::sampleSpecialStats() {}
 
-void HostStatSampler::closeSpecialStats() {
-}
+void HostStatSampler::closeSpecialStats() {}
 
 void HostStatSampler::checkListeners() {}
 

-- 
To stop receiving notification emails like this one, please contact
jbarrett@apache.org.