Package org.apache.hadoop.hbase.index.util

Examples of org.apache.hadoop.hbase.index.util.SecondaryIndexColocator


      admin.move(regionsEncod1.get(i), null);
      admin.move(regionsEncod2.get(i), null);
    }

    ZKAssign.blockUntilNoRIT(zkw);
    SecondaryIndexColocator colocator = new SecondaryIndexColocator(config);
    colocator.setUp();
    boolean inconsistent = colocator.checkForCoLocationInconsistency();
    Assert.assertTrue("Inconsistency should be there before running the tool.", inconsistent);
    colocator.fixCoLocationInconsistency();

    ZKAssign.blockUntilNoRIT(zkw);

    colocator = new SecondaryIndexColocator(config);
    colocator.setUp();
    inconsistent = colocator.checkForCoLocationInconsistency();
    Assert.assertFalse("No inconsistency should be there after running the tool", inconsistent);
  }
View Full Code Here


      admin.assign(newRegions.get(i).getRegionName());
    }
    ZKAssign.blockUntilNoRIT(HBaseTestingUtility.getZooKeeperWatcher(UTIL));
    master.getAssignmentManager().getZKTable().setDisablingTable(table2);

    SecondaryIndexColocator colocator = new SecondaryIndexColocator(UTIL.getConfiguration());
    colocator.setUp();
    boolean inconsistent = colocator.checkForCoLocationInconsistency();
    List<RegionServerThread> serverThreads =
        UTIL.getMiniHBaseCluster().getLiveRegionServerThreads();
    List<HRegionServer> rs = new ArrayList<HRegionServer>();
    for (RegionServerThread regionServerThread : serverThreads) {
      rs.add(regionServerThread.getRegionServer());
View Full Code Here

    for (int i = 0; i < newRegions.size() / 2; i++) {
      admin.assign(newRegions.get(i).getRegionName());
    }
    master.getAssignmentManager().getZKTable().setEnabledTable(table2);

    SecondaryIndexColocator colocator = new SecondaryIndexColocator(UTIL.getConfiguration());
    colocator.setUp();
    colocator.checkForCoLocationInconsistency();
    List<RegionServerThread> serverThreads =
        UTIL.getMiniHBaseCluster().getLiveRegionServerThreads();
    List<HRegionServer> rs = new ArrayList<HRegionServer>();
    for (RegionServerThread regionServerThread : serverThreads) {
      rs.add(regionServerThread.getRegionServer());
View Full Code Here

    for (int i = 0; i < newRegions.size() / 2; i++) {
      admin.assign(newRegions.get(i).getRegionName());
    }
    master.getAssignmentManager().getZKTable().setEnabledTable(table2);

    SecondaryIndexColocator colocator = new SecondaryIndexColocator(UTIL.getConfiguration());
    colocator.setUp();
    colocator.checkForCoLocationInconsistency();
    List<RegionServerThread> serverThreads =
        UTIL.getMiniHBaseCluster().getLiveRegionServerThreads();
    List<HRegionServer> rs = new ArrayList<HRegionServer>();
    for (RegionServerThread regionServerThread : serverThreads) {
      rs.add(regionServerThread.getRegionServer());
View Full Code Here

    ZKAssign.blockUntilNoRIT(HBaseTestingUtility.getZooKeeperWatcher(UTIL));
    admin.disableTable(table2);
    ZKAssign.blockUntilNoRIT(HBaseTestingUtility.getZooKeeperWatcher(UTIL));

    List<HRegionInfo> tableRegions = admin.getTableRegions(Bytes.toBytes(table2));
    SecondaryIndexColocator colocator = new SecondaryIndexColocator(UTIL.getConfiguration());
    colocator.setUp();
    boolean inconsistent = colocator.checkForCoLocationInconsistency();
    List<RegionServerThread> serverThreads =
        UTIL.getMiniHBaseCluster().getLiveRegionServerThreads();

    List<HRegionServer> rs = new ArrayList<HRegionServer>();
    for (RegionServerThread regionServerThread : serverThreads) {
View Full Code Here

    for (int i = 0; i < 5; i++) {
      MetaEditor.updateRegionLocation(master.getCatalogTracker(), tableRegions.get(i), sn);
    }

    SecondaryIndexColocator colocator = new SecondaryIndexColocator(UTIL.getConfiguration());
    colocator.setUp();
    colocator.checkForCoLocationInconsistency();

    List<RegionServerThread> serverThreads =
        UTIL.getMiniHBaseCluster().getLiveRegionServerThreads();
    List<HRegionServer> rs = new ArrayList<HRegionServer>();
    for (RegionServerThread regionServerThread : serverThreads) {
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.index.util.SecondaryIndexColocator

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.