You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by bb...@apache.org on 2020/03/05 19:49:45 UTC

[geode-native] branch develop updated: GEODE-2484: Removes more ACE mutex. (#578)

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

bbender 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 7594277  GEODE-2484: Removes more ACE mutex. (#578)
7594277 is described below

commit 75942777fe05893bdd9fa17c58c13fde5d4c30af
Author: Blake Bender <bb...@pivotal.io>
AuthorDate: Thu Mar 5 11:49:37 2020 -0800

    GEODE-2484: Removes more ACE mutex. (#578)
    
    - Cleanup other ACE headers.
---
 cppcache/src/CacheImpl.cpp                    | 17 ++++++-------
 cppcache/src/CacheImpl.hpp                    |  5 ++--
 cppcache/src/CppCacheLibrary.cpp              | 16 +-----------
 cppcache/src/CppCacheLibrary.hpp              | 16 ++++++------
 cppcache/src/CqQueryVsdStats.cpp              | 14 +----------
 cppcache/src/CqQueryVsdStats.hpp              |  2 --
 cppcache/src/CqServiceVsdStats.cpp            | 11 --------
 cppcache/src/CqServiceVsdStats.hpp            |  2 --
 cppcache/src/MapSegment.cpp                   | 36 +++++++++++++--------------
 cppcache/src/MapSegment.hpp                   |  2 +-
 cppcache/src/PoolStatistics.cpp               | 13 +---------
 cppcache/src/PoolStatistics.hpp               |  2 --
 cppcache/src/RegionStats.cpp                  |  9 +------
 cppcache/src/SerializationRegistry.cpp        |  3 ---
 cppcache/src/TcrEndpoint.hpp                  | 12 ---------
 cppcache/src/ThinClientPoolDM.hpp             |  1 +
 cppcache/src/ThinClientRedundancyManager.hpp  |  3 ++-
 cppcache/src/statistics/HostStatSampler.cpp   |  3 ---
 cppcache/src/statistics/HostStatSampler.hpp   |  2 --
 cppcache/src/statistics/StatArchiveWriter.cpp |  4 ---
 20 files changed, 42 insertions(+), 131 deletions(-)

diff --git a/cppcache/src/CacheImpl.cpp b/cppcache/src/CacheImpl.cpp
index caeec99..cb051f4 100644
--- a/cppcache/src/CacheImpl.cpp
+++ b/cppcache/src/CacheImpl.cpp
@@ -17,10 +17,6 @@
 
 #include "CacheImpl.hpp"
 
-#include <string>
-
-#include <ace/Guard_T.h>
-
 #include <geode/CacheStatistics.hpp>
 #include <geode/PersistenceManager.hpp>
 #include <geode/PoolManager.hpp>
@@ -164,7 +160,7 @@ CacheImpl::RegionKind CacheImpl::getRegionKind(
 }
 
 void CacheImpl::removeRegion(const std::string& name) {
-  ACE_Guard<ACE_Recursive_Thread_Mutex> lock(m_destroyCacheMutex, 1);
+  std::lock_guard<decltype(m_destroyCacheMutex)> lock(m_destroyCacheMutex);
   if (!m_destroyPending) {
     m_regions.erase(name);
   }
@@ -244,7 +240,7 @@ void CacheImpl::close(bool keepalive) {
   sendNotificationCloseMsgs();
 
   {
-    ACE_Guard<ACE_Recursive_Thread_Mutex> lock(m_destroyCacheMutex, 1);
+    std::lock_guard<decltype(m_destroyCacheMutex)> lock(m_destroyCacheMutex);
     if (m_destroyPending) {
       return;
     }
@@ -330,8 +326,8 @@ void CacheImpl::close(bool keepalive) {
 }
 
 bool CacheImpl::doIfDestroyNotPending(std::function<void()> f) {
-  ACE_Guard<ACE_Recursive_Thread_Mutex> lock(m_destroyCacheMutex, 1);
-  if (lock.locked() && !m_destroyPending) {
+  std::lock_guard<decltype(m_destroyCacheMutex)> lock(m_destroyCacheMutex);
+  if (!m_destroyPending) {
     f();
   }
 
@@ -465,7 +461,7 @@ std::shared_ptr<Region> CacheImpl::getRegion(const std::string& path) {
   LOGDEBUG("CacheImpl::getRegion " + path);
 
   this->throwIfClosed();
-  ACE_Guard<ACE_Recursive_Thread_Mutex> lock(m_destroyCacheMutex, 1);
+  std::lock_guard<decltype(m_destroyCacheMutex)> lock(m_destroyCacheMutex);
 
   if (m_destroyPending) {
     return nullptr;
@@ -680,7 +676,8 @@ bool CacheImpl::getEndpointStatus(const std::string& endpoint) {
 }
 
 void CacheImpl::processMarker() {
-  ACE_Guard<ACE_Recursive_Thread_Mutex> destroy_lock(m_destroyCacheMutex, 1);
+  std::lock_guard<decltype(m_destroyCacheMutex)> destroy_lock(
+      m_destroyCacheMutex);
   if (m_destroyPending) {
     return;
   }
diff --git a/cppcache/src/CacheImpl.hpp b/cppcache/src/CacheImpl.hpp
index b5f4441..7ef8036 100644
--- a/cppcache/src/CacheImpl.hpp
+++ b/cppcache/src/CacheImpl.hpp
@@ -23,8 +23,7 @@
 #include <atomic>
 #include <memory>
 #include <mutex>
-
-#include <ace/Recursive_Thread_Mutex.h>
+#include <string>
 
 #include <geode/Cache.hpp>
 #include <geode/PoolManager.hpp>
@@ -374,7 +373,7 @@ class APACHE_GEODE_EXPORT CacheImpl : private NonCopyable,
   std::unique_ptr<EvictionController> m_evictionController;
   TcrConnectionManager* m_tcrConnectionManager;
   std::shared_ptr<RemoteQueryService> m_remoteQueryServicePtr;
-  ACE_Recursive_Thread_Mutex m_destroyCacheMutex;
+  std::recursive_mutex m_destroyCacheMutex;
   volatile bool m_destroyPending;
   volatile bool m_initDone;
   std::mutex m_initDoneLock;
diff --git a/cppcache/src/CppCacheLibrary.cpp b/cppcache/src/CppCacheLibrary.cpp
index 3a68cee..4bdd4cf 100644
--- a/cppcache/src/CppCacheLibrary.cpp
+++ b/cppcache/src/CppCacheLibrary.cpp
@@ -17,24 +17,10 @@
 
 #include "CppCacheLibrary.hpp"
 
-#include <string>
-
 #include <ace/ACE.h>
 #include <ace/Init_ACE.h>
-#include <ace/Log_Msg.h>
-#include <ace/Singleton.h>
-
-#include <geode/CacheFactory.hpp>
-#include <geode/DataOutput.hpp>
-
-#include "ExpMapEntry.hpp"
-#include "LRUExpMapEntry.hpp"
-#include "LRUMapEntry.hpp"
-#include "MapEntry.hpp"
-#include "SerializationRegistry.hpp"
-#include "TcrMessage.hpp"
+
 #include "Utils.hpp"
-#include "config.h"
 
 // called during DLL initialization
 void initLibDllEntry(void) {
diff --git a/cppcache/src/CppCacheLibrary.hpp b/cppcache/src/CppCacheLibrary.hpp
index cafe977..42eb14a 100644
--- a/cppcache/src/CppCacheLibrary.hpp
+++ b/cppcache/src/CppCacheLibrary.hpp
@@ -1,8 +1,3 @@
-#pragma once
-
-#ifndef GEODE_CPPCACHELIBRARY_H_
-#define GEODE_CPPCACHELIBRARY_H_
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
@@ -20,6 +15,11 @@
  * limitations under the License.
  */
 
+#pragma once
+
+#ifndef GEODE_CPPCACHELIBRARY_H_
+#define GEODE_CPPCACHELIBRARY_H_
+
 #include <string>
 
 #include <geode/internal/geode_globals.hpp>
@@ -33,19 +33,17 @@ class APACHE_GEODE_EXPORT CppCacheLibrary {
  public:
   // Call to this to trigger initialization.
   static void initLib(void);
+
   // Call to this to trigger cleanup.  initLib and closeLib calls must be in
   // pairs.
   static void closeLib(void);
 
-  // Returns pathname of product's lib directory, adds 'addon' to it if 'addon'
-  // is not null.
-  static std::string getProductLibDir(const char* addon);
-
   // Returns the directory where the library/DLL resides
   static std::string getProductLibDir();
 
   static std::string getProductDir();
 };
+
 }  // namespace client
 }  // namespace geode
 }  // namespace apache
diff --git a/cppcache/src/CqQueryVsdStats.cpp b/cppcache/src/CqQueryVsdStats.cpp
index 5b2924d..54840ab 100644
--- a/cppcache/src/CqQueryVsdStats.cpp
+++ b/cppcache/src/CqQueryVsdStats.cpp
@@ -15,17 +15,6 @@
  * limitations under the License.
  */
 
-#include <mutex>
-
-#include "util/concurrent/spinlock_mutex.hpp"
-
-const char* cqStatsName = "CqQueryStatistics";
-const char* cqStatsDesc = "Statistics for this cq query";
-#include <ace/Singleton.h>
-#include <ace/Thread_Mutex.h>
-
-#include <geode/internal/geode_globals.hpp>
-
 #include "CqQueryVsdStats.hpp"
 
 namespace apache {
@@ -33,8 +22,6 @@ namespace geode {
 namespace client {
 
 using statistics::StatisticsFactory;
-using std::lock_guard;
-using util::concurrent::spinlock_mutex;
 
 constexpr const char* CqQueryVsdStats::STATS_NAME;
 constexpr const char* CqQueryVsdStats::STATS_DESC;
@@ -82,6 +69,7 @@ CqQueryVsdStats::~CqQueryVsdStats() {
     m_cqQueryVsdStats = nullptr;
   }
 }
+
 }  // namespace client
 }  // namespace geode
 }  // namespace apache
diff --git a/cppcache/src/CqQueryVsdStats.hpp b/cppcache/src/CqQueryVsdStats.hpp
index b4dbf73..715862d 100644
--- a/cppcache/src/CqQueryVsdStats.hpp
+++ b/cppcache/src/CqQueryVsdStats.hpp
@@ -27,7 +27,6 @@
 
 #include "statistics/Statistics.hpp"
 #include "statistics/StatisticsFactory.hpp"
-#include "util/concurrent/spinlock_mutex.hpp"
 
 namespace apache {
 namespace geode {
@@ -36,7 +35,6 @@ namespace client {
 using statistics::StatisticDescriptor;
 using statistics::Statistics;
 using statistics::StatisticsType;
-using util::concurrent::spinlock_mutex;
 
 class APACHE_GEODE_EXPORT CqQueryVsdStats : public CqStatistics {
  public:
diff --git a/cppcache/src/CqServiceVsdStats.cpp b/cppcache/src/CqServiceVsdStats.cpp
index e520eb2..397434b 100644
--- a/cppcache/src/CqServiceVsdStats.cpp
+++ b/cppcache/src/CqServiceVsdStats.cpp
@@ -17,22 +17,11 @@
 
 #include "CqServiceVsdStats.hpp"
 
-#include <mutex>
-
-#include <ace/Singleton.h>
-#include <ace/Thread_Mutex.h>
-
-#include <geode/internal/geode_globals.hpp>
-
-#include "statistics/StatisticsFactory.hpp"
-
 namespace apache {
 namespace geode {
 namespace client {
 
 using statistics::StatisticsFactory;
-using std::lock_guard;
-using util::concurrent::spinlock_mutex;
 
 constexpr const char* CqServiceVsdStats::STATS_NAME;
 constexpr const char* CqServiceVsdStats::STATS_DESC;
diff --git a/cppcache/src/CqServiceVsdStats.hpp b/cppcache/src/CqServiceVsdStats.hpp
index c6cd8de..5272ff1 100644
--- a/cppcache/src/CqServiceVsdStats.hpp
+++ b/cppcache/src/CqServiceVsdStats.hpp
@@ -27,7 +27,6 @@
 
 #include "statistics/Statistics.hpp"
 #include "statistics/StatisticsFactory.hpp"
-#include "util/concurrent/spinlock_mutex.hpp"
 
 namespace apache {
 namespace geode {
@@ -36,7 +35,6 @@ namespace client {
 using statistics::StatisticDescriptor;
 using statistics::Statistics;
 using statistics::StatisticsType;
-using util::concurrent::spinlock_mutex;
 
 class APACHE_GEODE_EXPORT CqServiceVsdStats : public CqServiceStatistics {
  public:
diff --git a/cppcache/src/MapSegment.cpp b/cppcache/src/MapSegment.cpp
index 37d3a7b..ca94941 100644
--- a/cppcache/src/MapSegment.cpp
+++ b/cppcache/src/MapSegment.cpp
@@ -60,7 +60,7 @@ void MapSegment::open(RegionInternal* region, const EntryFactory* entryFactory,
 void MapSegment::close() {}
 
 void MapSegment::clear() {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   m_map->clear();
 }
 
@@ -78,7 +78,7 @@ GfErrType MapSegment::create(const std::shared_ptr<CacheableKey>& key,
   TombstoneExpiryHandler* handler = nullptr;
   GfErrType err = GF_NOERR;
   {
-    std::lock_guard<spinlock_mutex> lk(m_spinlock);
+    std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
     // if size is greater than 75 percent of prime, rehash
     auto mapSize = TableOfPrimes::getPrime(m_primeIndex);
     if (((m_map->size() * 75) / 100) > mapSize) {
@@ -148,7 +148,7 @@ GfErrType MapSegment::put(const std::shared_ptr<CacheableKey>& key,
   TombstoneExpiryHandler* handler = nullptr;
   GfErrType err = GF_NOERR;
   {
-    std::lock_guard<spinlock_mutex> lk(m_spinlock);
+    std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
     // if size is greater than 75 percent of prime, rehash
     uint32_t mapSize = TableOfPrimes::getPrime(m_primeIndex);
     if (((m_map->size() * 75) / 100) > mapSize) {
@@ -213,7 +213,7 @@ GfErrType MapSegment::invalidate(const std::shared_ptr<CacheableKey>& key,
                                  std::shared_ptr<Cacheable>& oldValue,
                                  std::shared_ptr<VersionTag> versionTag,
                                  bool& isTokenAdded) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   isTokenAdded = false;
   GfErrType err = GF_NOERR;
 
@@ -339,7 +339,7 @@ GfErrType MapSegment::remove(const std::shared_ptr<CacheableKey>& key,
     bool expTaskSet = false;
     GfErrType err;
     {
-      std::lock_guard<spinlock_mutex> lk(m_spinlock);
+      std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
       err = removeWhenConcurrencyEnabled(key, oldValue, me, updateCount,
                                          versionTag, afterRemote, isEntryFound,
                                          id, handler, expTaskSet);
@@ -352,7 +352,7 @@ GfErrType MapSegment::remove(const std::shared_ptr<CacheableKey>& key,
     return err;
   }
 
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   if (m_map->erase(key) == 0) {
     // didn't unbind, probably no entry...
     oldValue = nullptr;
@@ -399,7 +399,7 @@ bool MapSegment::unguardedRemoveActualEntryWithoutCancelTask(
 
 bool MapSegment::removeActualEntry(const std::shared_ptr<CacheableKey>& key,
                                    bool cancelTask) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   return unguardedRemoveActualEntry(key, cancelTask);
 }
 /**
@@ -408,7 +408,7 @@ bool MapSegment::removeActualEntry(const std::shared_ptr<CacheableKey>& key,
 bool MapSegment::getEntry(const std::shared_ptr<CacheableKey>& key,
                           std::shared_ptr<MapEntryImpl>& result,
                           std::shared_ptr<Cacheable>& value) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   const auto& find = m_map->find(key);
   if (find == m_map->end()) {
@@ -434,7 +434,7 @@ bool MapSegment::getEntry(const std::shared_ptr<CacheableKey>& key,
  * @brief return true if there exists an entry for the key.
  */
 bool MapSegment::containsKey(const std::shared_ptr<CacheableKey>& key) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   const auto& find = m_map->find(key);
   if (find == m_map->end()) {
@@ -455,7 +455,7 @@ bool MapSegment::containsKey(const std::shared_ptr<CacheableKey>& key) {
  * @brief return the all the keys in the provided list.
  */
 void MapSegment::getKeys(std::vector<std::shared_ptr<CacheableKey>>& result) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   for (const auto& kv : *m_map) {
     std::shared_ptr<Cacheable> valuePtr;
@@ -470,7 +470,7 @@ void MapSegment::getKeys(std::vector<std::shared_ptr<CacheableKey>>& result) {
  * @brief return all the entries in the provided list.
  */
 void MapSegment::getEntries(std::vector<std::shared_ptr<RegionEntry>>& result) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   for (const auto& kv : *m_map) {
     std::shared_ptr<CacheableKey> keyPtr;
@@ -492,7 +492,7 @@ void MapSegment::getEntries(std::vector<std::shared_ptr<RegionEntry>>& result) {
  * @brief return all values in the provided list.
  */
 void MapSegment::getValues(std::vector<std::shared_ptr<Cacheable>>& result) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   for (const auto& kv : *m_map) {
     auto& entry = kv.second;
     std::shared_ptr<Cacheable> value;
@@ -520,7 +520,7 @@ int MapSegment::addTrackerForEntry(const std::shared_ptr<CacheableKey>& key,
                                    bool addIfAbsent, bool failIfPresent,
                                    bool incUpdateCount) {
   if (m_concurrencyChecksEnabled) return -1;
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   std::shared_ptr<MapEntry> entry;
   std::shared_ptr<MapEntry> newEntry;
   const auto& find = m_map->find(key);
@@ -569,7 +569,7 @@ int MapSegment::addTrackerForEntry(const std::shared_ptr<CacheableKey>& key,
 void MapSegment::removeTrackerForEntry(
     const std::shared_ptr<CacheableKey>& key) {
   if (m_concurrencyChecksEnabled) return;
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   const auto& find = m_map->find(key);
   if (find != m_map->end()) {
@@ -585,7 +585,7 @@ void MapSegment::removeTrackerForEntry(
 void MapSegment::addTrackerForAllEntries(
     MapOfUpdateCounters& updateCounterMap) {
   if (m_concurrencyChecksEnabled) return;
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
 
   std::shared_ptr<MapEntry> newEntry;
   std::shared_ptr<CacheableKey> key;
@@ -604,7 +604,7 @@ void MapSegment::addTrackerForAllEntries(
 // changes takes care of the version and no need for tracking the entry
 void MapSegment::removeDestroyTracking() {
   if (m_concurrencyChecksEnabled) return;
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   m_destroyedKeys.clear();
 }
 
@@ -718,11 +718,11 @@ GfErrType MapSegment::putForTrackedEntry(
   }
 }
 void MapSegment::reapTombstones(std::map<uint16_t, int64_t>& gcVersions) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   m_tombstoneList->reapTombstones(gcVersions);
 }
 void MapSegment::reapTombstones(std::shared_ptr<CacheableHashSet> removedKeys) {
-  std::lock_guard<spinlock_mutex> lk(m_spinlock);
+  std::lock_guard<decltype(m_spinlock)> lk(m_spinlock);
   m_tombstoneList->reapTombstones(removedKeys);
 }
 
diff --git a/cppcache/src/MapSegment.hpp b/cppcache/src/MapSegment.hpp
index 3e00989..47f7b62 100644
--- a/cppcache/src/MapSegment.hpp
+++ b/cppcache/src/MapSegment.hpp
@@ -60,7 +60,7 @@ class APACHE_GEODE_EXPORT MapSegment {
 
   // index of the current prime in the primes table
   uint32_t m_primeIndex;
-  spinlock_mutex m_spinlock;
+  util::concurrent::spinlock_mutex m_spinlock;
   std::recursive_mutex m_segmentMutex;
 
   bool m_concurrencyChecksEnabled;
diff --git a/cppcache/src/PoolStatistics.cpp b/cppcache/src/PoolStatistics.cpp
index 098c959..37470de 100644
--- a/cppcache/src/PoolStatistics.cpp
+++ b/cppcache/src/PoolStatistics.cpp
@@ -17,24 +17,12 @@
 
 #include "PoolStatistics.hpp"
 
-#include <geode/internal/geode_globals.hpp>
-//#include "StatisticsFactory.hpp"
-
-#include <mutex>
-
-#include <ace/Singleton.h>
-
-#include "util/concurrent/spinlock_mutex.hpp"
-
-////////////////////////////////////////////////////////////////////////////////
-
 namespace apache {
 namespace geode {
 namespace client {
 
 using statistics::StatisticsFactory;
 using statistics::StatisticsManager;
-using util::concurrent::spinlock_mutex;
 
 constexpr const char* PoolStats::STATS_NAME;
 constexpr const char* PoolStats::STATS_DESC;
@@ -200,6 +188,7 @@ PoolStats::~PoolStats() {
     m_poolStats = nullptr;
   }
 }
+
 }  // namespace client
 }  // namespace geode
 }  // namespace apache
diff --git a/cppcache/src/PoolStatistics.hpp b/cppcache/src/PoolStatistics.hpp
index 8b7e861..da68413 100644
--- a/cppcache/src/PoolStatistics.hpp
+++ b/cppcache/src/PoolStatistics.hpp
@@ -26,7 +26,6 @@
 #include "statistics/Statistics.hpp"
 #include "statistics/StatisticsFactory.hpp"
 #include "statistics/StatisticsManager.hpp"
-#include "util/concurrent/spinlock_mutex.hpp"
 
 namespace apache {
 namespace geode {
@@ -35,7 +34,6 @@ namespace client {
 using statistics::StatisticDescriptor;
 using statistics::Statistics;
 using statistics::StatisticsType;
-using util::concurrent::spinlock_mutex;
 
 class PoolStats {
  public:
diff --git a/cppcache/src/RegionStats.cpp b/cppcache/src/RegionStats.cpp
index 1a9c98e..558bbf2 100644
--- a/cppcache/src/RegionStats.cpp
+++ b/cppcache/src/RegionStats.cpp
@@ -17,19 +17,11 @@
 
 #include "RegionStats.hpp"
 
-#include <ace/Singleton.h>
-#include <ace/Thread_Mutex.h>
-
-#include <geode/internal/geode_globals.hpp>
-
-#include "util/concurrent/spinlock_mutex.hpp"
-
 namespace apache {
 namespace geode {
 namespace client {
 
 using statistics::StatisticsFactory;
-using util::concurrent::spinlock_mutex;
 
 constexpr const char* RegionStats::STATS_NAME;
 constexpr const char* RegionStats::STATS_DESC;
@@ -202,6 +194,7 @@ RegionStats::~RegionStats() {
     m_regionStats = nullptr;
   }
 }
+
 }  // namespace client
 }  // namespace geode
 }  // namespace apache
diff --git a/cppcache/src/SerializationRegistry.cpp b/cppcache/src/SerializationRegistry.cpp
index 08f7b83..9f97891 100644
--- a/cppcache/src/SerializationRegistry.cpp
+++ b/cppcache/src/SerializationRegistry.cpp
@@ -20,9 +20,6 @@
 #include <functional>
 #include <mutex>
 
-#include <ace/Singleton.h>
-#include <ace/Thread_Mutex.h>
-
 #include <geode/CacheableBuiltins.hpp>
 #include <geode/CacheableDate.hpp>
 #include <geode/CacheableEnum.hpp>
diff --git a/cppcache/src/TcrEndpoint.hpp b/cppcache/src/TcrEndpoint.hpp
index cf527d3..e63b9a1 100644
--- a/cppcache/src/TcrEndpoint.hpp
+++ b/cppcache/src/TcrEndpoint.hpp
@@ -27,7 +27,6 @@
 #include <string>
 #include <unordered_set>
 
-#include <ace/Condition_Recursive_Thread_Mutex.h>
 #include <ace/Semaphore.h>
 
 #include <geode/internal/geode_base.hpp>
@@ -59,21 +58,16 @@ class TcrEndpoint {
       ACE_Semaphore& redundancySema, ThinClientBaseDM* dm = nullptr,
       bool isMultiUserMode = false);  // TODO: need to look for endpoint case
 
-  /* adongre
-   * CID 29000: Non-virtual destructor (VIRTUAL_DTOR)
-   */
   virtual ~TcrEndpoint();
 
   virtual GfErrType registerDM(bool clientNotification,
                                bool isSecondary = false,
                                bool isActiveEndpoint = false,
                                ThinClientBaseDM* distMgr = nullptr);
-  // GfErrType registerPoolDM( bool isSecondary, ThinClientPoolHADM* poolDM );
 
   virtual void unregisterDM(bool clientNotification,
                             ThinClientBaseDM* distMgr = nullptr,
                             bool checkQueueHosted = false);
-  // void unregisterPoolDM(  );
 
   void pingServer(ThinClientPoolDM* poolDM = nullptr);
   void receiveNotification(std::atomic<bool>& isRunning);
@@ -127,12 +121,6 @@ class TcrEndpoint {
   }
 
   virtual bool isMultiUserMode();
-  /*{
-    if(m_baseDM != nullptr)
-      return this->m_baseDM->isMultiUserMode();
-    else
-      return false;
-  }*/
 
   void authenticateEndpoint(TcrConnection*& conn);
 
diff --git a/cppcache/src/ThinClientPoolDM.hpp b/cppcache/src/ThinClientPoolDM.hpp
index 782f2ff..702dbf7 100644
--- a/cppcache/src/ThinClientPoolDM.hpp
+++ b/cppcache/src/ThinClientPoolDM.hpp
@@ -27,6 +27,7 @@
 #include <string>
 #include <vector>
 
+#include <ace/Condition_Recursive_Thread_Mutex.h>
 #include <ace/Recursive_Thread_Mutex.h>
 #include <ace/Semaphore.h>
 
diff --git a/cppcache/src/ThinClientRedundancyManager.hpp b/cppcache/src/ThinClientRedundancyManager.hpp
index 5794e50..a9c3dc4 100644
--- a/cppcache/src/ThinClientRedundancyManager.hpp
+++ b/cppcache/src/ThinClientRedundancyManager.hpp
@@ -28,7 +28,8 @@
 #include <set>
 #include <string>
 
-#include <ace/ACE.h>
+#include <ace/Semaphore.h>
+#include <ace/Time_Value.h>
 
 #include "ErrType.hpp"
 #include "EventIdMap.hpp"
diff --git a/cppcache/src/statistics/HostStatSampler.cpp b/cppcache/src/statistics/HostStatSampler.cpp
index 4b221d5..d180cb5 100644
--- a/cppcache/src/statistics/HostStatSampler.cpp
+++ b/cppcache/src/statistics/HostStatSampler.cpp
@@ -18,20 +18,17 @@
 #include "HostStatSampler.hpp"
 
 #include <chrono>
-#include <exception>
 #include <thread>
 #include <utility>
 #include <vector>
 
 #include <ace/ACE.h>
-#include <ace/Dirent.h>
 #include <ace/Dirent_Selector.h>
 #include <ace/INET_Addr.h>
 #include <ace/OS_NS_sys_stat.h>
 #include <ace/OS_NS_sys_utsname.h>
 #include <boost/process/environment.hpp>
 
-#include <geode/SystemProperties.hpp>
 #include <geode/internal/geode_globals.hpp>
 
 #include "../CacheImpl.hpp"
diff --git a/cppcache/src/statistics/HostStatSampler.hpp b/cppcache/src/statistics/HostStatSampler.hpp
index a15f5e7..e3f6a2a 100644
--- a/cppcache/src/statistics/HostStatSampler.hpp
+++ b/cppcache/src/statistics/HostStatSampler.hpp
@@ -28,8 +28,6 @@
 #include <thread>
 #include <vector>
 
-#include <ace/Task.h>
-
 #include <geode/ExceptionTypes.hpp>
 #include <geode/internal/geode_globals.hpp>
 
diff --git a/cppcache/src/statistics/StatArchiveWriter.cpp b/cppcache/src/statistics/StatArchiveWriter.cpp
index 16ce4d6..cd7a5b9 100644
--- a/cppcache/src/statistics/StatArchiveWriter.cpp
+++ b/cppcache/src/statistics/StatArchiveWriter.cpp
@@ -20,12 +20,8 @@
 #include <chrono>
 #include <ctime>
 
-#include <ace/ACE.h>
-#include <ace/OS_NS_sys_time.h>
 #include <ace/OS_NS_sys_utsname.h>
 #include <ace/OS_NS_time.h>
-#include <ace/Task.h>
-#include <ace/Thread_Mutex.h>
 
 #include <geode/internal/geode_globals.hpp>