Package org.apache.hadoop.hbase

Examples of org.apache.hadoop.hbase.RegionHistorian$RegionHistoryInformation


      // delayedToDoQueue, so return true so the operation is not put
      // back on the toDoQueue
      return true;
    }

    final RegionHistorian historian = RegionHistorian.getInstance();
    HRegionInterface server =
        master.connection.getHRegionConnection(getMetaRegion().getServer());
    LOG.info(regionInfo.getRegionNameAsString() + " open on " +
        serverInfo.getServerAddress().toString());

    // Register the newly-available Region's location.
    Put p = new Put(regionInfo.getRegionName());
    p.add(CATALOG_FAMILY, SERVER_QUALIFIER,
      Bytes.toBytes(serverInfo.getServerAddress().toString()));
    p.add(CATALOG_FAMILY, STARTCODE_QUALIFIER,
      Bytes.toBytes(serverInfo.getStartCode()));
    server.put(metaRegionName, p);
    LOG.info("Updated row " + regionInfo.getRegionNameAsString() +
      " in region " + Bytes.toString(metaRegionName) + " with startcode=" +
      serverInfo.getStartCode() + ", server=" + serverInfo.getServerAddress());
    if (!historian.isOnline()) {
      // This is safest place to do the onlining of the historian in
      // the master.  When we get to here, we know there is a .META.
      // for the historian to go against.
      historian.online(this.master.getConfiguration());
    }
    historian.addRegionOpen(regionInfo, serverInfo.getServerAddress());
    synchronized (master.regionManager) {
      if (isMetaTable) {
        // It's a meta region.
        MetaRegion m =
            new MetaRegion(new HServerAddress(serverInfo.getServerAddress()),
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.RegionHistorian$RegionHistoryInformation

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.