Package org.apache.hadoop.hbase.regionserver.SplitTransaction

Examples of org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitInfo


      }
    }
  }

  public SplitInfo preSplitBeforePONR(byte[] splitKey) throws IOException {
    SplitInfo info = null;
    ObserverContext<RegionCoprocessorEnvironment> ctx = null;
    for (RegionEnvironment env : coprocessors) {
      if (env.getInstance() instanceof RegionObserverExt) {
        ctx = ObserverContext.createAndPrepare(env, ctx);
        try {
View Full Code Here


                + " failed. So returning null. ");
            return null;
          }
          indexRegion.forceSplit(splitKey);
          PairOfSameType<HRegion> daughterRegions = st.stepsBeforeAddingPONR(rs, rs, false);
          SplitInfo splitInfo = splitThreadLocal.get();
          splitInfo.setDaughtersAndTransaction(daughterRegions, st);
          LOG.info("Daughter regions created for the index table " + indexTableName
              + " for the region " + indexRegion.getRegionInfo());
          return splitInfo;
        } else {
          LOG.error("IndexRegion for the table " + indexTableName + " is null. So returning null. ");
          return null;
        }
      } catch (Exception ex) {
        LOG.error("Error while spliting the indexTabRegion or not able to get the indexTabRegion:"
            + indexRegion != null ? indexRegion.getRegionName() : "", ex);
        st.rollback(rs, rs);
        return null;
      }
    }
    LOG.trace("Indexes for the table " + userTableName
        + " are null. So returning the empty SplitInfo");
    return new SplitInfo();
  }
View Full Code Here

  @Override
  public void preSplit(ObserverContext<RegionCoprocessorEnvironment> e) throws IOException {
    if (splitThreadLocal != null) {
      splitThreadLocal.remove();
      splitThreadLocal.set(new SplitInfo());
    }
  }
View Full Code Here

        + region.getRegionInfo());
    IndexManager indexManager = IndexManager.getInstance();
    SplitTransaction splitTransaction = null;
    if (indexManager.getIndicesForTable(userTableName) != null) {
      try {
        SplitInfo splitInfo = splitThreadLocal.get();
        splitTransaction = splitInfo.getSplitTransaction();
        PairOfSameType<HRegion> daughters = splitInfo.getDaughters();
        if (splitTransaction != null && daughters != null) {
          splitTransaction.stepsAfterPONR(rs, rs, daughters);
          LOG.info("Daughter regions are opened and split transaction finished"
              + " for zknodes for index table " + indexTableName + " for the region "
              + region.getRegionInfo());
View Full Code Here

    if (IndexUtils.isIndexTable(userTableName)) {
      return;
    }
    LOG.trace("Entering preRollBack for the table " + userTableName + " for the region "
        + region.getRegionInfo());
    SplitInfo splitInfo = splitThreadLocal.get();
    SplitTransaction splitTransaction = splitInfo.getSplitTransaction();
    try {
      if (splitTransaction != null) {
        splitTransaction.rollback(rs, rs);
        LOG.info("preRollBack successfully done for the table " + userTableName
            + " for the region " + region.getRegionInfo());
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitInfo

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.