当前位置: 首页>>代码示例>>Java>>正文


Java StorefileRefresherChore类代码示例

本文整理汇总了Java中org.apache.hadoop.hbase.regionserver.StorefileRefresherChore的典型用法代码示例。如果您正苦于以下问题:Java StorefileRefresherChore类的具体用法?Java StorefileRefresherChore怎么用?Java StorefileRefresherChore使用的例子?那么, 这里精选的类代码示例或许可以为您提供帮助。


StorefileRefresherChore类属于org.apache.hadoop.hbase.regionserver包,在下文中一共展示了StorefileRefresherChore类的7个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: beforeClass

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void beforeClass() throws Exception {
  // enable store file refreshing
  HTU.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, REFRESH_PERIOD);

  HTU.getConfiguration().setFloat("hbase.regionserver.logroll.multiplier", 0.0001f);
  HTU.getConfiguration().setInt("replication.source.size.capacity", 10240);
  HTU.getConfiguration().setLong("replication.source.sleepforretries", 100);
  HTU.getConfiguration().setInt("hbase.regionserver.maxlogs", 2);
  HTU.getConfiguration().setLong("hbase.master.logcleaner.ttl", 10);
  HTU.getConfiguration().setInt("zookeeper.recovery.retry", 1);
  HTU.getConfiguration().setInt("zookeeper.recovery.retry.intervalmill", 10);

  HTU.startMiniCluster(NB_SERVERS);
  HTU.getHBaseCluster().startMaster();
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:18,代码来源:TestReplicaWithCluster.java

示例2: setUp

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void setUp() throws Exception {
  // Set up the integration test util
  if (util == null) {
    util = new IntegrationTestingUtility();
  }
  util.getConfiguration().setInt(HConstants.META_REPLICAS_NUM, 3);
  util.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, 1000);
  // Make sure there are three servers.
  util.initializeCluster(3);
  ZooKeeperWatcher zkw = util.getZooKeeperWatcher();
  Configuration conf = util.getConfiguration();
  String baseZNode = conf.get(HConstants.ZOOKEEPER_ZNODE_PARENT,
      HConstants.DEFAULT_ZOOKEEPER_ZNODE_PARENT);
  String primaryMetaZnode = ZKUtil.joinZNode(baseZNode,
      conf.get("zookeeper.znode.metaserver", "meta-region-server"));
  // check that the data in the znode is parseable (this would also mean the znode exists)
  byte[] data = ZKUtil.getData(zkw, primaryMetaZnode);
  ServerName.parseFrom(data);
  waitUntilZnodeAvailable(1);
  waitUntilZnodeAvailable(2);
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:24,代码来源:IntegrationTestMetaReplicas.java

示例3: setUp

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void setUp() throws Exception {
  // Set up the integration test util
  if (util == null) {
    util = new IntegrationTestingUtility();
  }
  util.getConfiguration().setInt(HConstants.META_REPLICAS_NUM, 3);
  util.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, 1000);
  // Make sure there are three servers.
  util.initializeCluster(3);
  ZKWatcher zkw = util.getZooKeeperWatcher();
  Configuration conf = util.getConfiguration();
  String baseZNode = conf.get(HConstants.ZOOKEEPER_ZNODE_PARENT,
      HConstants.DEFAULT_ZOOKEEPER_ZNODE_PARENT);
  String primaryMetaZnode = ZNodePaths.joinZNode(baseZNode,
      conf.get("zookeeper.znode.metaserver", "meta-region-server"));
  // check that the data in the znode is parseable (this would also mean the znode exists)
  byte[] data = ZKUtil.getData(zkw, primaryMetaZnode);
  ProtobufUtil.toServerName(data);
  waitUntilZnodeAvailable(1);
  waitUntilZnodeAvailable(2);
}
 
开发者ID:apache,项目名称:hbase,代码行数:24,代码来源:IntegrationTestMetaReplicas.java

示例4: setup

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@Before
public void setup() throws Exception {
  TEST_UTIL.getConfiguration().setInt("zookeeper.session.timeout", 30000);
  TEST_UTIL.getConfiguration().setInt(HConstants.META_REPLICAS_NUM, 3);
  TEST_UTIL.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, 1000);
  TEST_UTIL.startMiniCluster(3);
  // disable the balancer
  LoadBalancerTracker l = new LoadBalancerTracker(TEST_UTIL.getZooKeeperWatcher(),
      new Abortable() {
    boolean aborted = false;
    @Override
    public boolean isAborted() {
      return aborted;
    }
    @Override
    public void abort(String why, Throwable e) {
      aborted = true;
    }
  });
  l.setBalancerOn(false);
  for (int replicaId = 1; replicaId < 3; replicaId ++) {
    HRegionInfo h = RegionReplicaUtil.getRegionInfoForReplica(HRegionInfo.FIRST_META_REGIONINFO,
      replicaId);
    TEST_UTIL.getMiniHBaseCluster().getMaster().getAssignmentManager().waitForAssignment(h);
  }
  LOG.debug("All meta replicas assigned");
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:29,代码来源:TestMetaWithReplicas.java

示例5: beforeClass

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void beforeClass() throws Exception {
  // enable store file refreshing
  HTU.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, REFRESH_PERIOD);
  HTU.getConfiguration().setBoolean("hbase.client.log.scanner.activity", true);
  ConnectionUtils.setupMasterlessConnection(HTU.getConfiguration());
  HTU.startMiniCluster(NB_SERVERS);

  // Create table then get the single region for our new table.
  HTableDescriptor hdt = HTU.createTableDescriptor(TestReplicasClient.class.getSimpleName());
  hdt.addCoprocessor(SlowMeCopro.class.getName());
  table = HTU.createTable(hdt, new byte[][]{f}, HTU.getConfiguration());

  hriPrimary = table.getRegionLocation(row, false).getRegionInfo();

  // mock a secondary region info to open
  hriSecondary = new HRegionInfo(hriPrimary.getTable(), hriPrimary.getStartKey(),
      hriPrimary.getEndKey(), hriPrimary.isSplit(), hriPrimary.getRegionId(), 1);

  // No master
  LOG.info("Master is going to be stopped");
  TestRegionServerNoMaster.stopMasterAndAssignMeta(HTU);
  Configuration c = new Configuration(HTU.getConfiguration());
  c.setInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER, 1);
  LOG.info("Master has stopped");
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:28,代码来源:TestReplicasClient.java

示例6: beforeClass

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void beforeClass() throws Exception {
  // enable store file refreshing
  HTU.getConfiguration().setInt(StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD,
      REFRESH_PERIOD);

  HTU.getConfiguration().setFloat("hbase.regionserver.logroll.multiplier", 0.0001f);
  HTU.getConfiguration().setInt("replication.source.size.capacity", 10240);
  HTU.getConfiguration().setLong("replication.source.sleepforretries", 100);
  HTU.getConfiguration().setInt("hbase.regionserver.maxlogs", 2);
  HTU.getConfiguration().setLong("hbase.master.logcleaner.ttl", 10);
  HTU.getConfiguration().setInt("zookeeper.recovery.retry", 1);
  HTU.getConfiguration().setInt("zookeeper.recovery.retry.intervalmill", 10);

  // Wait for primary call longer so make sure that it will get exception from the primary call
  HTU.getConfiguration().setInt("hbase.client.primaryCallTimeout.get", 1000000);
  HTU.getConfiguration().setInt("hbase.client.primaryCallTimeout.scan", 1000000);

  // Retry less so it can fail faster
  HTU.getConfiguration().setInt("hbase.client.retries.number", 1);

  // Enable meta replica at server side
  HTU.getConfiguration().setInt("hbase.meta.replica.count", 2);

  // Make sure master does not host system tables.
  HTU.getConfiguration().set("hbase.balancer.tablesOnMaster", "none");

  // Set system coprocessor so it can be applied to meta regions
  HTU.getConfiguration().set("hbase.coprocessor.region.classes",
      RegionServerHostingPrimayMetaRegionSlowOrStopCopro.class.getName());

  HTU.getConfiguration().setInt(HConstants.HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT,
      META_SCAN_TIMEOUT_IN_MILLISEC * 1000);

  HTU.startMiniCluster(NB_SERVERS);
  HTU.getHBaseCluster().startMaster();
}
 
开发者ID:apache,项目名称:hbase,代码行数:38,代码来源:TestReplicaWithCluster.java

示例7: beforeClass

import org.apache.hadoop.hbase.regionserver.StorefileRefresherChore; //导入依赖的package包/类
@BeforeClass
public static void beforeClass() throws Exception {
  // enable store file refreshing
  HTU.getConfiguration().setInt(
      StorefileRefresherChore.REGIONSERVER_STOREFILE_REFRESH_PERIOD, REFRESH_PERIOD);
  HTU.getConfiguration().setBoolean("hbase.client.log.scanner.activity", true);
  HTU.getConfiguration().setBoolean(MetricsConnection.CLIENT_SIDE_METRICS_ENABLED_KEY, true);
  ConnectionUtils.setupMasterlessConnection(HTU.getConfiguration());
  HTU.startMiniCluster(NB_SERVERS);

  // Create table then get the single region for our new table.
  HTableDescriptor hdt = HTU.createTableDescriptor(TestReplicasClient.class.getSimpleName());
  hdt.addCoprocessor(SlowMeCopro.class.getName());
  table = HTU.createTable(hdt, new byte[][]{f}, null);

  try (RegionLocator locator = HTU.getConnection().getRegionLocator(hdt.getTableName())) {
    hriPrimary = locator.getRegionLocation(row, false).getRegionInfo();
  }

  // mock a secondary region info to open
  hriSecondary = new HRegionInfo(hriPrimary.getTable(), hriPrimary.getStartKey(),
      hriPrimary.getEndKey(), hriPrimary.isSplit(), hriPrimary.getRegionId(), 1);

  // No master
  LOG.info("Master is going to be stopped");
  TestRegionServerNoMaster.stopMasterAndAssignMeta(HTU);
  Configuration c = new Configuration(HTU.getConfiguration());
  c.setInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER, 1);
  LOG.info("Master has stopped");
}
 
开发者ID:apache,项目名称:hbase,代码行数:31,代码来源:TestReplicasClient.java


注:本文中的org.apache.hadoop.hbase.regionserver.StorefileRefresherChore类示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。