You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ds...@apache.org on 2015/10/26 19:28:47 UTC

[24/50] [abbrv] incubator-geode git commit: GEODE-429: Remove Cache.createHdfsStoreFactory method

GEODE-429: Remove Cache.createHdfsStoreFactory method


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

Branch: refs/heads/develop
Commit: f2390a1ada2acbcabac28dd4226a67f7baf924ae
Parents: 74c3156
Author: Ashvin Agrawal <as...@apache.org>
Authored: Mon Oct 19 15:05:36 2015 -0700
Committer: Ashvin Agrawal <as...@apache.org>
Committed: Wed Oct 21 08:55:23 2015 -0700

----------------------------------------------------------------------
 .../gemstone/gemfire/cache/GemFireCache.java    |   8 -
 .../internal/cache/GemFireCacheImpl.java        |   6 -
 .../internal/cache/xmlcache/CacheCreation.java  |   5 -
 .../HDFSRegionMBeanAttributeJUnitTest.java      | 169 -------------------
 4 files changed, 188 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f2390a1a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
index d81d25d..b948c5d 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/GemFireCache.java
@@ -267,12 +267,4 @@ public interface GemFireCache extends RegionService {
    * @param name the name of the HDFSStore to find.
    */
   public HDFSStore findHDFSStore(String name);
-
-   /**
-	* Creates a {@link HDFSStoreFactory} for creating a {@link HDFSStore}
-	* 
-	* @return the HDFS store factory
-	*/
-  public HDFSStoreFactory createHDFSStoreFactory();
-  
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f2390a1a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index 0d4961b..78ea6be 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -5309,12 +5309,6 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
     }
   }
   
-  @Override
-  public HDFSStoreFactory createHDFSStoreFactory() {
-    // TODO Auto-generated method stub
-    return new HDFSStoreFactoryImpl(this);
-  }
-  
   public HDFSStoreFactory createHDFSStoreFactory(HDFSStoreCreation creation) {
     return new HDFSStoreFactoryImpl(this, creation);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f2390a1a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java
index 0347d67..e4bea7f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/CacheCreation.java
@@ -1378,11 +1378,6 @@ public class CacheCreation implements InternalCache, Extensible<Cache> {
   }
   
   @Override
-  public HDFSStoreFactory createHDFSStoreFactory() {
-    // TODO Auto-generated method stub
-    return new HDFSStoreFactoryImpl(this);
-  }
-  @Override
   public HDFSStore findHDFSStore(String storeName) {
     return (HDFSStore)this.hdfsStores.get(storeName);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f2390a1a/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/HDFSRegionMBeanAttributeJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/HDFSRegionMBeanAttributeJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/HDFSRegionMBeanAttributeJUnitTest.java
deleted file mode 100644
index 14b61e6..0000000
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/HDFSRegionMBeanAttributeJUnitTest.java
+++ /dev/null
@@ -1,169 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package com.gemstone.gemfire.management.bean.stats;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.Set;
-
-import junit.framework.TestCase;
-
-import org.apache.hadoop.fs.Path;
-import org.apache.hadoop.hbase.io.hfile.BlockCache;
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.hdfs.HDFSStoreFactory;
-import com.gemstone.gemfire.cache.hdfs.internal.HDFSStoreImpl;
-import com.gemstone.gemfire.cache.hdfs.internal.SortedHDFSQueuePersistedEvent;
-import com.gemstone.gemfire.cache.hdfs.internal.hoplog.HoplogConfig;
-import com.gemstone.gemfire.cache.hdfs.internal.hoplog.HoplogOrganizer;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.HFileStoreStatistics;
-import com.gemstone.gemfire.internal.cache.persistence.soplog.SortedOplogStatistics;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.management.ManagementService;
-import com.gemstone.gemfire.management.RegionMXBean;
-import com.gemstone.gemfire.management.internal.ManagementConstants;
-import com.gemstone.gemfire.test.junit.categories.HoplogTest;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest
-;
-
-/**
- * Test for verifying HDFS related MBean attributes
- * @author rishim
- *
- */
-@Category({IntegrationTest.class, HoplogTest.class})
-public class HDFSRegionMBeanAttributeJUnitTest extends TestCase {
-
-  public static final String HDFS_STORE_NAME = "HDFSMBeanJUnitTestStore";
-  public static final String REGION_NAME = "HDFSMBeanJUnitTest_Region";
-  protected Path testDataDir;
-  protected Cache cache;
-
-  protected HDFSStoreFactory hsf;
-  protected HDFSStoreImpl hdfsStore;
-  protected Region<Object, Object> region;
-  SortedOplogStatistics stats;
-  HFileStoreStatistics storeStats;
-  BlockCache blockCache;
-
-  @Override
-  protected void setUp() throws Exception {
-    super.setUp();
-
-    System.setProperty(HoplogConfig.ALLOW_LOCAL_HDFS_PROP, "true");
-    testDataDir = new Path("test-case");
-
-    cache = createCache();
-
-    configureHdfsStoreFactory();
-    hdfsStore = (HDFSStoreImpl) hsf.create(HDFS_STORE_NAME);
-
-    RegionFactory<Object, Object> regionfactory = cache.createRegionFactory(RegionShortcut.PARTITION);
-//    regionfactory.setHDFSStoreName(HDFS_STORE_NAME);
-
-    // regionfactory.setCompressionCodec("Some");
-    PartitionAttributesFactory fac = new PartitionAttributesFactory();
-    fac.setTotalNumBuckets(10);
-
-    regionfactory.setPartitionAttributes(fac.create());
-    region = regionfactory.create(REGION_NAME);
-
-  }
-
-  protected void configureHdfsStoreFactory() throws Exception {
-    hsf = this.cache.createHDFSStoreFactory();
-    hsf.setHomeDir(testDataDir.toString());
-  }
-
-  protected Cache createCache() {
-    CacheFactory cf = new CacheFactory().set("mcast-port", "0").set("log-level", "info");
-    cache = cf.create();
-    return cache;
-  }
-
-  @Override
-  protected void tearDown() throws Exception {
-    hdfsStore.getFileSystem().delete(testDataDir, true);
-    cache.close();
-    super.tearDown();
-  }
-
-  public void testStoreUsageStats() throws Exception {
-
-    PartitionedRegion parRegion = (PartitionedRegion)region;
-   
-
-      ArrayList<TestEvent> items = new ArrayList<TestEvent>();
-      for (int i = 0; i < 100; i++) {
-        String key = ("key-" + (i * 100 + i));
-        String value = ("value-" + System.nanoTime());
-        parRegion.put(key, value);
-        
-        items.add(new TestEvent(key, value));
-      }
-
-    //Dont want to create
-    Set<BucketRegion> localPrimaryBucketRegions = parRegion.getDataStore().getAllLocalPrimaryBucketRegions();
-    BucketRegion flushingBucket=  localPrimaryBucketRegions.iterator().next();
-    HoplogOrganizer hoplogOrganizer = getOrganizer(parRegion,flushingBucket.getId());
-    hoplogOrganizer.flush(items.iterator(), 100);
-    
-    GemFireCacheImpl cache = GemFireCacheImpl.getExisting();
-    ManagementService service = ManagementService.getExistingManagementService(cache);
-    RegionMXBean bean = service.getLocalRegionMBean(region.getFullPath());
-    
-
-    //assertTrue(bean.getEntryCount() == ManagementConstants.ZERO);
-    assertTrue(bean.getEntrySize() == ManagementConstants.NOT_AVAILABLE_LONG);
-    assertTrue(0 < bean.getDiskUsage());
-    
-  }
-  
-  
-  private HoplogOrganizer getOrganizer(PartitionedRegion region, int bucketId) {
-    BucketRegion br = region.getDataStore().getLocalBucketById(bucketId);
-    if (br == null) {
-      // got rebalanced or something
-      throw new BucketMovedException("Bucket region is no longer available. BucketId: " + 
-          bucketId +  " RegionPath: "  +  region.getFullPath());
-    }
-
-    return br.getHoplogOrganizer();
-  }
- 
-  
-  public static class TestEvent extends SortedHDFSQueuePersistedEvent implements Serializable {
-    private static final long serialVersionUID = 1L;
-    
-    Object key;
-    
-    public TestEvent(String k, String v) throws Exception {
-      this(k, v, Operation.PUT_IF_ABSENT);
-    }
-
-    public TestEvent(String k, String v, Operation op) throws Exception {
-      super(v, op, (byte) 0x02, false, new DiskVersionTag(), BlobHelper.serializeToBlob(k), 0);
-      this.key = k; 
-    }
-  }
-
-
-}