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

[geode-native] branch develop updated: GEODE-5120: Remove DistributedSystem from public API.

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

echobravo 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 5b1411f  GEODE-5120: Remove DistributedSystem from public API.
5b1411f is described below

commit 5b1411fe80174fcb3b306c1b426161389df1c9e3
Author: Jacob Barrett <jb...@pivotal.io>
AuthorDate: Tue Apr 24 10:07:05 2018 -0700

    GEODE-5120: Remove DistributedSystem from public API.
---
 clicache/integration-test/CacheHelperN.cs   |  12 ----
 clicache/integration-test/OverflowTestsN.cs |   6 +-
 clicache/src/Cache.cpp                      |   5 +-
 clicache/src/Cache.hpp                      |  16 +----
 clicache/src/DistributedSystem.hpp          |   2 +-
 clicache/src/IGeodeCache.hpp                |  14 +---
 cppcache/include/geode/Cache.hpp            |   9 +--
 cppcache/include/geode/GeodeCache.hpp       |   8 +--
 cppcache/integration-test/CMakeLists.txt    |   1 -
 cppcache/integration-test/CacheHelper.cpp   |  16 +----
 cppcache/integration-test/testConnect.cpp   |  47 -------------
 cppcache/src/Cache.cpp                      |  13 ++--
 cppcache/src/CacheFactory.cpp               |  10 +--
 cppcache/src/CacheImpl.hpp                  |   4 ++
 cppcache/src/PoolFactory.cpp                | 102 ++++++++++++++--------------
 tests/cli/NewFwkLib/CacheHelper.cs          |  12 ----
 tests/cli/NewFwkLib/CacheServer.cs          |   6 +-
 tests/cli/NewFwkLib/PerfTest/PerfTests.cs   |  10 +--
 18 files changed, 91 insertions(+), 202 deletions(-)

diff --git a/clicache/integration-test/CacheHelperN.cs b/clicache/integration-test/CacheHelperN.cs
index 879106e..0ad0ae4 100644
--- a/clicache/integration-test/CacheHelperN.cs
+++ b/clicache/integration-test/CacheHelperN.cs
@@ -341,17 +341,6 @@ namespace Apache.Geode.Client.UnitTests
       }
     }
 
-    public static DistributedSystem DSYS
-    {
-      get
-      {
-        return m_dsys;
-      }
-      set
-      {
-        m_dsys = value;
-      }
-    }
     public static CacheTransactionManager CSTXManager
     {
       get
@@ -625,7 +614,6 @@ namespace Apache.Geode.Client.UnitTests
         }
       }
 
-      m_dsys = m_cache.DistributedSystem;
       m_cstxManager = m_cache.CacheTransactionManager;
     }
 
diff --git a/clicache/integration-test/OverflowTestsN.cs b/clicache/integration-test/OverflowTestsN.cs
index e655d71..2ef32fe 100644
--- a/clicache/integration-test/OverflowTestsN.cs
+++ b/clicache/integration-test/OverflowTestsN.cs
@@ -36,10 +36,7 @@ namespace Apache.Geode.Client.UnitTests
 
   public class OverflowTests : UnitTests
   {
-    private DistributedSystem m_dsys = null;
-
-    private const string DSYSName = "OverflowTest";
-
+   
     protected override ClientBase[] GetClients()
     {
       return null;
@@ -49,7 +46,6 @@ namespace Apache.Geode.Client.UnitTests
     public override void InitTests()
     {
       base.InitTests();
-      m_dsys = CacheHelper.DSYS;
     }
 
     [TestFixtureTearDown]
diff --git a/clicache/src/Cache.cpp b/clicache/src/Cache.cpp
index 8fdf078..9c133fd 100644
--- a/clicache/src/Cache.cpp
+++ b/clicache/src/Cache.cpp
@@ -81,11 +81,12 @@ namespace Apache
         }
       }
 
-      DistributedSystem^ Cache::DistributedSystem::get( )
+      SystemProperties^ Cache::SystemProperties::get( )
       {
         try
         {
-          return Client::DistributedSystem::Create(&(m_nativeptr->get()->getDistributedSystem()));
+          auto&& systemProperties = m_nativeptr->get()->getSystemProperties();
+          return Apache::Geode::Client::SystemProperties::Create(&systemProperties);
         }
         finally
         {
diff --git a/clicache/src/Cache.hpp b/clicache/src/Cache.hpp
index 89b4930..1835101 100644
--- a/clicache/src/Cache.hpp
+++ b/clicache/src/Cache.hpp
@@ -43,9 +43,7 @@ namespace Apache
       enum class ExpirationAction;
 
       enum class RegionShortcut;
-      
-      ref class DistributedSystem;
-      
+            
       ref class CacheTransactionManager2PC;
       
       generic<class TPropKey, class TPropValue>
@@ -113,17 +111,9 @@ namespace Apache
           bool get();
         }
 
-        /// <summary>
-        /// Returns the distributed system used to
-        /// <see cref="CacheFactory.Create" /> this cache.
-        /// </summary>
-        /// <remarks>
-        /// This method does not throw
-        /// <c>CacheClosedException</c> if the cache is closed.
-        /// </remarks>
-        virtual property Apache::Geode::Client::DistributedSystem^ DistributedSystem
+        virtual property SystemProperties^ SystemProperties
         {
-          Apache::Geode::Client::DistributedSystem^ get();
+          Apache::Geode::Client::SystemProperties^ get();
         }
 
         /// <summary>
diff --git a/clicache/src/DistributedSystem.hpp b/clicache/src/DistributedSystem.hpp
index c186550..7e0e27c 100644
--- a/clicache/src/DistributedSystem.hpp
+++ b/clicache/src/DistributedSystem.hpp
@@ -48,7 +48,7 @@ namespace Apache
       /// distributed system, each application needs to connect to the
       /// DistributedSystem.
       /// </remarks>
-      public ref class DistributedSystem sealed
+      private ref class DistributedSystem sealed
       {
       public:
 
diff --git a/clicache/src/IGeodeCache.hpp b/clicache/src/IGeodeCache.hpp
index 2141615..5cb526c 100644
--- a/clicache/src/IGeodeCache.hpp
+++ b/clicache/src/IGeodeCache.hpp
@@ -31,7 +31,7 @@ namespace Apache
     namespace Client
     {
 
-      ref class DistributedSystem;
+      ref class SystemProperties;
 
       ref class CacheTransactionManager;
 
@@ -76,17 +76,9 @@ namespace Apache
         /// <param name="cacheXml">pathname of a <c>cache.xml</c> file</param>
         void InitializeDeclarativeCache(String^ cacheXml);
 
-        /// <summary>
-        /// Returns the distributed system used to
-        /// <see cref="CacheFactory.Create" /> this cache.
-        /// </summary>
-        /// <remarks>
-        /// This method does not throw
-        /// <c>CacheClosedException</c> if the cache is closed.
-        /// </remarks>
-        property DistributedSystem^ DistributedSystem
+        property SystemProperties^ SystemProperties
         {
-          Apache::Geode::Client::DistributedSystem^ get();
+          Apache::Geode::Client::SystemProperties^ get();
         }
 
         /// <summary>
diff --git a/cppcache/include/geode/Cache.hpp b/cppcache/include/geode/Cache.hpp
index ccad4df..4b67070 100644
--- a/cppcache/include/geode/Cache.hpp
+++ b/cppcache/include/geode/Cache.hpp
@@ -41,7 +41,6 @@ class CacheRegionHelper;
 class CacheTransactionManager;
 class DataInput;
 class DataOutput;
-class DistributedSystem;
 class Pool;
 class PoolFactory;
 class PoolManager;
@@ -104,12 +103,6 @@ class APACHE_GEODE_EXPORT Cache : public GeodeCache {
   bool isClosed() const override;
 
   /**
-   * Returns the distributed system that this cache was
-   * {@link CacheFactory created} with.
-   */
-  DistributedSystem& getDistributedSystem() const override;
-
-  /**
    * Returns the type registry that this cache was
    * {@link CacheFactory::create created} with.
    */
@@ -245,6 +238,8 @@ class APACHE_GEODE_EXPORT Cache : public GeodeCache {
 
   virtual PoolManager& getPoolManager() const;
 
+  SystemProperties& getSystemProperties() const override;
+
   Cache() = delete;
   virtual ~Cache();
   Cache(const Cache& other) = delete;
diff --git a/cppcache/include/geode/GeodeCache.hpp b/cppcache/include/geode/GeodeCache.hpp
index fe59834..19a45f2 100644
--- a/cppcache/include/geode/GeodeCache.hpp
+++ b/cppcache/include/geode/GeodeCache.hpp
@@ -31,7 +31,7 @@ namespace apache {
 namespace geode {
 namespace client {
 
-class DistributedSystem;
+class SystemProperties;
 
 /**
  * GeodeCache represents the singleton cache that must be created
@@ -71,11 +71,7 @@ class APACHE_GEODE_EXPORT GeodeCache : public RegionService {
    */
   virtual void initializeDeclarativeCache(const std::string& cacheXml) = 0;
 
-  /**
-   * Returns the distributed system that this cache was
-   * {@link CacheFactory created} with.
-   */
-  virtual DistributedSystem& getDistributedSystem() const = 0;
+  virtual SystemProperties& getSystemProperties() const = 0;
 
   /**
    * Returns whether Cache saves unread fields for Pdx types.
diff --git a/cppcache/integration-test/CMakeLists.txt b/cppcache/integration-test/CMakeLists.txt
index 1e3b1a5..e6477fe 100644
--- a/cppcache/integration-test/CMakeLists.txt
+++ b/cppcache/integration-test/CMakeLists.txt
@@ -141,7 +141,6 @@ set_property(TEST testRegionMap PROPERTY LABELS STABLE QUICK)
 set_property(TEST testXmlCacheCreationWithRefid PROPERTY LABELS STABLE QUICK)
 set_property(TEST testRegionAttributesFactory PROPERTY LABELS STABLE QUICK)
 set_property(TEST testXmlCacheCreationWithOverFlow PROPERTY LABELS STABLE QUICK)
-set_property(TEST testConnect PROPERTY LABELS STABLE QUICK)
 set_property(TEST testThinClientRemoveAllLocal PROPERTY LABELS STABLE QUICK)
 set_property(TEST testDunit PROPERTY LABELS STABLE QUICK)
 set_property(TEST testAttributesMutator PROPERTY LABELS STABLE QUICK)
diff --git a/cppcache/integration-test/CacheHelper.cpp b/cppcache/integration-test/CacheHelper.cpp
index ac67cd9..56895b7 100644
--- a/cppcache/integration-test/CacheHelper.cpp
+++ b/cppcache/integration-test/CacheHelper.cpp
@@ -318,15 +318,6 @@ void CacheHelper::disconnect(bool keepalive) {
   }
 
   LOG("Closed cache.");
-  try {
-    if (m_doDisconnect) {
-      LOG("Disconnecting...");
-      cachePtr->getDistributedSystem().disconnect();
-      LOG("Finished disconnect.");
-    }
-  } catch (...) {
-    LOG("Throwing exception while disconnecting....");
-  }
   cachePtr = nullptr;
   singleton = nullptr;
   LOG("Finished cleanup after CacheHelper.");
@@ -1746,17 +1737,16 @@ void CacheHelper::initLocator(int instance, bool ssl, bool, int dsId,
 void CacheHelper::clearSecProp() {
   auto tmpSecProp = CacheHelper::getHelper()
                         .getCache()
-                        ->getDistributedSystem()
-                        .getSystemProperties()
+                        ->getSystemProperties()
                         .getSecurityProperties();
   tmpSecProp->remove("security-username");
   tmpSecProp->remove("security-password");
 }
+
 void CacheHelper::setJavaConnectionPoolSize(long size) {
   CacheHelper::getHelper()
       .getCache()
-      ->getDistributedSystem()
-      .getSystemProperties()
+      ->getSystemProperties()
       .setjavaConnectionPoolSize(size);
 }
 
diff --git a/cppcache/integration-test/testConnect.cpp b/cppcache/integration-test/testConnect.cpp
deleted file mode 100644
index 9d42478..0000000
--- a/cppcache/integration-test/testConnect.cpp
+++ /dev/null
@@ -1,47 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-#include "fw_dunit.hpp"
-#include <geode/CacheFactory.hpp>
-
-using namespace apache::geode::client;
-
-const char* host_name = "Suds";
-DUNIT_TASK(s1p1, CreateRegionOne)
-  {
-    auto factory = CacheFactory();
-    auto cache = std::make_shared<Cache>(factory.create());
-    try {
-      cache->getDistributedSystem().connect();
-      FAIL("Expected an exception.");
-    } catch (const AlreadyConnectedException& ex) {
-      LOG("Got expected exception.");
-      LOG(ex.what());
-    }
-
-    cache->getDistributedSystem().disconnect();
-
-    try {
-      // doing second disconnect to force the exception
-      cache->getDistributedSystem().disconnect();
-      FAIL("Expected an exception.");
-    } catch (const NotConnectedException& ex) {
-      LOG("Got expected exception.");
-      LOG(ex.what());
-    }
-  }
-ENDTASK
diff --git a/cppcache/src/Cache.cpp b/cppcache/src/Cache.cpp
index 52b3847..75f879d 100644
--- a/cppcache/src/Cache.cpp
+++ b/cppcache/src/Cache.cpp
@@ -53,15 +53,6 @@ const std::string& Cache::getName() const { return m_cacheImpl->getName(); }
 bool Cache::isClosed() const { return m_cacheImpl->isClosed(); }
 
 /**
- * Returns the distributed system that this cache was
- * {@link CacheFactory::create created} with. This method does not throw
- * <code>CacheClosedException</code> if the cache is closed.
- */
-DistributedSystem& Cache::getDistributedSystem() const {
-  return m_cacheImpl->getDistributedSystem();
-}
-
-/**
  * Returns the type registry that this cache was
  * {@link CacheFactory::create created} with.
  */
@@ -170,6 +161,10 @@ PoolManager& Cache::getPoolManager() const {
   return m_cacheImpl->getPoolManager();
 }
 
+SystemProperties& Cache::getSystemProperties() const {
+  return m_cacheImpl->getSystemProperties();
+}
+
 std::unique_ptr<DataInput> Cache::createDataInput(const uint8_t* m_buffer,
                                                   size_t len) const {
   return m_cacheImpl->createDataInput(m_buffer, len);
diff --git a/cppcache/src/CacheFactory.cpp b/cppcache/src/CacheFactory.cpp
index 2d7dd18..ded4acc 100644
--- a/cppcache/src/CacheFactory.cpp
+++ b/cppcache/src/CacheFactory.cpp
@@ -72,8 +72,9 @@ Cache CacheFactory::create() const {
       Cache(dsProp, ignorePdxUnreadFields, pdxReadSerialized, authInitialize);
 
   try {
-    auto&& cacheXml =
-        cache.getDistributedSystem().getSystemProperties().cacheXMLFile();
+    auto&& cacheXml = cache.m_cacheImpl->getDistributedSystem()
+                          .getSystemProperties()
+                          .cacheXMLFile();
     if (!cacheXml.empty()) {
       cache.initializeDeclarativeCache(cacheXml);
     } else {
@@ -132,8 +133,9 @@ Cache CacheFactory::create(
   cache.m_cacheImpl->setAttributes(attrs);
 
   try {
-    auto&& cacheXml =
-        cache.getDistributedSystem().getSystemProperties().cacheXMLFile();
+    auto&& cacheXml = cache.m_cacheImpl->getDistributedSystem()
+                          .getSystemProperties()
+                          .cacheXMLFile();
     if (!cacheXml.empty()) {
       cache.initializeDeclarativeCache(cacheXml);
     } else {
diff --git a/cppcache/src/CacheImpl.hpp b/cppcache/src/CacheImpl.hpp
index 673c342..aab924c 100644
--- a/cppcache/src/CacheImpl.hpp
+++ b/cppcache/src/CacheImpl.hpp
@@ -279,6 +279,10 @@ class APACHE_GEODE_EXPORT CacheImpl : private NonCopyable,
 
   PoolManager& getPoolManager() const { return *m_poolManager; }
 
+  SystemProperties& getSystemProperties() const {
+    return m_distributedSystem.getSystemProperties();
+  }
+
   ThreadPool* getThreadPool();
 
   inline const std::shared_ptr<AuthInitialize>& getAuthInitialize() {
diff --git a/cppcache/src/PoolFactory.cpp b/cppcache/src/PoolFactory.cpp
index 52b2ed4..4ad6da6 100644
--- a/cppcache/src/PoolFactory.cpp
+++ b/cppcache/src/PoolFactory.cpp
@@ -233,73 +233,73 @@ PoolFactory& PoolFactory::setPRSingleHopEnabled(bool enabled) {
 }
 std::shared_ptr<Pool> PoolFactory::create(std::string name) {
   std::shared_ptr<ThinClientPoolDM> poolDM;
-  {
-    if (m_cache.getPoolManager().find(name) != nullptr) {
-      throw IllegalStateException("Pool with the same name already exists");
-    }
-    // Create a clone of Attr;
-    auto copyAttrs = m_attrs->clone();
 
-    auto cacheImpl = CacheRegionHelper::getCacheImpl(&m_cache);
+  auto&& poolManager = m_cache.getPoolManager();
 
-    if (m_cache.isClosed()) {
-      throw CacheClosedException("Cache is closed");
-    }
-    if (cacheImpl->getCacheMode() && m_isSubscriptionRedundancy) {
-      LOGWARN(
-          "At least one pool has been created so ignoring cache level "
-          "redundancy setting");
+  if (poolManager.find(name) != nullptr) {
+    throw IllegalStateException("Pool with the same name already exists");
+  }
+  // Create a clone of Attr;
+  auto copyAttrs = m_attrs->clone();
+
+  auto cacheImpl = CacheRegionHelper::getCacheImpl(&m_cache);
+
+  if (m_cache.isClosed()) {
+    throw CacheClosedException("Cache is closed");
+  }
+  if (cacheImpl->getCacheMode() && m_isSubscriptionRedundancy) {
+    LOGWARN(
+        "At least one pool has been created so ignoring cache level "
+        "redundancy setting");
+  }
+  auto&& tccm = cacheImpl->tcrConnectionManager();
+
+  LOGDEBUG("PoolFactory::create mulitusermode = %d ",
+           copyAttrs->getMultiuserSecureModeEnabled());
+  if (copyAttrs->getMultiuserSecureModeEnabled()) {
+    if (copyAttrs->getThreadLocalConnectionSetting()) {
+      LOGERROR(
+          "When pool [%s] is in multiuser authentication mode then thread "
+          "local connections are not supported.",
+          name.c_str());
+      throw IllegalArgumentException(
+          "When pool is in multiuser authentication mode then thread local "
+          "connections are not supported.");
     }
-    TcrConnectionManager& tccm = cacheImpl->tcrConnectionManager();
-
-    LOGDEBUG("PoolFactory::create mulitusermode = %d ",
-             copyAttrs->getMultiuserSecureModeEnabled());
-    if (copyAttrs->getMultiuserSecureModeEnabled()) {
-      if (copyAttrs->getThreadLocalConnectionSetting()) {
-        LOGERROR(
-            "When pool [%s] is in multiuser authentication mode then thread "
-            "local connections are not supported.",
-            name.c_str());
-        throw IllegalArgumentException(
-            "When pool is in multiuser authentication mode then thread local "
-            "connections are not supported.");
-      }
+  }
+  if (!copyAttrs->getSubscriptionEnabled() &&
+      copyAttrs->getSubscriptionRedundancy() == 0 && !tccm.isDurable()) {
+    if (copyAttrs->getThreadLocalConnectionSetting()) {
+      // TODO: what should we do for sticky connections
+      poolDM = std::make_shared<ThinClientPoolStickyDM>(name.c_str(), copyAttrs,
+                                                        tccm);
+    } else {
+      LOGDEBUG("ThinClientPoolDM created ");
+      poolDM =
+          std::make_shared<ThinClientPoolDM>(name.c_str(), copyAttrs, tccm);
     }
-    if (!copyAttrs->getSubscriptionEnabled() &&
-        copyAttrs->getSubscriptionRedundancy() == 0 && !tccm.isDurable()) {
-      if (copyAttrs->getThreadLocalConnectionSetting()) {
-        // TODO: what should we do for sticky connections
-        poolDM = std::make_shared<ThinClientPoolStickyDM>(name.c_str(),
+  } else {
+    LOGDEBUG("ThinClientPoolHADM created ");
+    if (copyAttrs->getThreadLocalConnectionSetting()) {
+      poolDM = std::make_shared<ThinClientPoolStickyHADM>(name.c_str(),
                                                           copyAttrs, tccm);
-      } else {
-        LOGDEBUG("ThinClientPoolDM created ");
-        poolDM =
-            std::make_shared<ThinClientPoolDM>(name.c_str(), copyAttrs, tccm);
-      }
     } else {
-      LOGDEBUG("ThinClientPoolHADM created ");
-      if (copyAttrs->getThreadLocalConnectionSetting()) {
-        poolDM = std::make_shared<ThinClientPoolStickyHADM>(name.c_str(),
-                                                            copyAttrs, tccm);
-      } else {
-        poolDM =
-            std::make_shared<ThinClientPoolHADM>(name.c_str(), copyAttrs, tccm);
-      }
+      poolDM =
+          std::make_shared<ThinClientPoolHADM>(name.c_str(), copyAttrs, tccm);
     }
-
-    cacheImpl->getPoolManager().addPool(name,
-                                        std::static_pointer_cast<Pool>(poolDM));
   }
 
+  poolManager.addPool(name, poolDM);
+
   // TODO: poolDM->init() should not throw exceptions!
   // Pool DM should only be inited once.
-  if (m_cache.getDistributedSystem()
+  if (cacheImpl->getDistributedSystem()
           .getSystemProperties()
           .autoReadyForEvents()) {
     poolDM->init();
   }
 
-  return std::static_pointer_cast<Pool>(poolDM);
+  return poolDM;
 }
 
 PoolFactory& PoolFactory::addCheck(const std::string& host, int port) {
diff --git a/tests/cli/NewFwkLib/CacheHelper.cs b/tests/cli/NewFwkLib/CacheHelper.cs
index 120c0eb..eb93535 100644
--- a/tests/cli/NewFwkLib/CacheHelper.cs
+++ b/tests/cli/NewFwkLib/CacheHelper.cs
@@ -99,7 +99,6 @@ namespace Apache.Geode.Client.FwkLib
   {
     #region Private static members and constants
 
-    private static DistributedSystem m_dsys = null;
     private static Cache m_cache = null;
     private static IRegion<TKey,TVal> m_currRegion = null;
 
@@ -149,14 +148,6 @@ namespace Apache.Geode.Client.FwkLib
 
     #region Public accessors
 
-    public static DistributedSystem DSYS
-    {
-      get
-      {
-        return m_dsys;
-      }
-    }
-
     public static Cache DCache
     {
       get
@@ -266,7 +257,6 @@ namespace Apache.Geode.Client.FwkLib
         }
       }
 
-      m_dsys = m_cache.DistributedSystem;
     }
 
     public static void InitConfigForPoolDurable(string durableClientId, int durableTimeout, string conflateEvents, bool isSslEnable)
@@ -300,7 +290,6 @@ namespace Apache.Geode.Client.FwkLib
     public static void Close()
     {
       CloseCache();
-      m_dsys = null;
     }
 
     public static void CloseCache()
@@ -315,7 +304,6 @@ namespace Apache.Geode.Client.FwkLib
     public static void CloseKeepAlive()
     {
       CloseCacheKeepAlive();
-      m_dsys = null;
     }
 
     public static void CloseCacheKeepAlive()
diff --git a/tests/cli/NewFwkLib/CacheServer.cs b/tests/cli/NewFwkLib/CacheServer.cs
index 41a18ce..7d4565d 100644
--- a/tests/cli/NewFwkLib/CacheServer.cs
+++ b/tests/cli/NewFwkLib/CacheServer.cs
@@ -1337,7 +1337,7 @@ namespace Apache.Geode.Client.FwkLib
           FwkInfo("Sleeping for " + sleepTime + " millis");
           Thread.Sleep(sleepTime);
           region.GetSubscriptionService().RegisterAllKeys(isDurable, isGetInitialValues, isReceiveValues);
-          String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+          String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
           if (durableClientId.Length > 0)
           {
               CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
@@ -2961,7 +2961,7 @@ namespace Apache.Geode.Client.FwkLib
               FwkInfo("Sleeping for " + sleepTime + " millis");
               Thread.Sleep(sleepTime);
               region.GetSubscriptionService().RegisterKeys(m_KeysA, isDurable, isGetInitialValues, isReceiveValues);
-              String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+              String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
               if (durableClientId.Length > 0)
               {
                   CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
@@ -3017,7 +3017,7 @@ namespace Apache.Geode.Client.FwkLib
                      verifyEntry(m_KeysA[i], expected);
                   templist.Clear();
               }
-              String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+              String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
               if (durableClientId.Length > 0)
               {
                   CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
diff --git a/tests/cli/NewFwkLib/PerfTest/PerfTests.cs b/tests/cli/NewFwkLib/PerfTest/PerfTests.cs
index a540f19..f02422c 100644
--- a/tests/cli/NewFwkLib/PerfTest/PerfTests.cs
+++ b/tests/cli/NewFwkLib/PerfTest/PerfTests.cs
@@ -1119,7 +1119,7 @@ namespace Apache.Geode.Client.FwkLib
           isReceiveValues = GetBoolValue("receiveValue");
         }
         region.GetSubscriptionService().RegisterKeys(registerKeyList, isDurable, isGetInitialValues, isReceiveValues);
-        String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+        String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
         if (durableClientId.Length > 0)
         {
           CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
@@ -1150,7 +1150,7 @@ namespace Apache.Geode.Client.FwkLib
           isReceiveValues = GetBoolValue("receiveValue");
         }
         region.GetSubscriptionService().RegisterAllKeys(isDurable, isGetInitialValues,isReceiveValues);
-        String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+        String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
         if (durableClientId.Length > 0)
         {
           CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
@@ -1244,7 +1244,7 @@ namespace Apache.Geode.Client.FwkLib
           isReceiveValues = GetBoolValue("receiveValue");
         }
         region.GetSubscriptionService().RegisterRegex(regex, isDurable, isGetInitialValues, isReceiveValues);
-        String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+        String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
         if (durableClientId.Length > 0)
         {
           CacheHelper<TKey, TVal>.DCache.ReadyForEvents();
@@ -1359,8 +1359,8 @@ namespace Apache.Geode.Client.FwkLib
         Int32 eventAfterUpdate = (Int32)Util.BBGet("ConflationCacheListener", "AFTER_UPDATE_COUNT_" + Util.ClientId + "_" + region.Name);
         
         FwkInfo("DoValidateQConflation() -- eventAfterCreate {0} and eventAfterUpdate {1}", eventAfterCreate, eventAfterUpdate);
-        String conflateEvent = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.ConflateEvents;
-        String durableClientId = CacheHelper<TKey, TVal>.DCache.DistributedSystem.SystemProperties.DurableClientId;
+        String conflateEvent = CacheHelper<TKey, TVal>.DCache.SystemProperties.ConflateEvents;
+        String durableClientId = CacheHelper<TKey, TVal>.DCache.SystemProperties.DurableClientId;
         Int32 totalCount = 3500;
         if(durableClientId.Length > 0) {
           FwkInfo("DoValidateQConflation() Validation for Durable client .");

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