Package org.apache.hadoop.hbase

Examples of org.apache.hadoop.hbase.HBaseTestingUtility.shutdownMiniCluster()


        LOG.debug("Waiting on regionserver to abort..");
      }
    }

    // cleanup
    util.shutdownMiniCluster();
  }
}
View Full Code Here


    // cleanup
    scanner.close();
    index.close();
    primary.close();
    util.shutdownMiniCluster();
  }

  /**
   * @param miniHBaseCluster
   * @param server
View Full Code Here

      }

      ht.close();
    } finally {
      if (cluster != null) {
        htu.shutdownMiniCluster();
      }
    }
  }

  private void runScanner(Table table, boolean slow) throws Exception {
View Full Code Here

      assertEquals(onlineServersList.size(), 2);
      cluster.shutdown();
    } finally {
      masterActive = false;
      firstRS.set(true);
      TEST_UTIL.shutdownMiniCluster();
    }
  }

  public static class MockedRegionServer extends MiniHBaseCluster.MiniHBaseClusterRegionServer {
View Full Code Here

    // TODO: Bring random 3 of 4 RS down at the same time

    ht.close();
    // Stop the cluster
    TEST_UTIL.shutdownMiniCluster();
  }

  private void blockUntilNoRIT(ZooKeeperWatcher zkw, HMaster master)
  throws KeeperException, InterruptedException {
    ZKAssign.blockUntilNoRIT(zkw);
View Full Code Here

      assertTrue(uniqueBlocksWeight1 == uniqueBlocksWeight2);

      ht.close();
    } finally {
      if (cluster != null) {
        htu.shutdownMiniCluster();
      }
    }
  }

  /**
 
View Full Code Here

      cluster.waitOnMaster(i);
    }
    // make sure all the masters properly shutdown
    assertEquals(0,masterThreads.size());
   
    TEST_UTIL.shutdownMiniCluster();
  }

  @Test(timeout = 180000)
  public void testMasterShutdownBeforeStartingAnyRegionServer() throws Exception {
View Full Code Here

    assertEquals("hdfs", fs.getUri().getScheme());

    try {
      testLinkReadDuringRename(fs, testUtil.getDefaultRootDirPath());
    } finally {
      testUtil.shutdownMiniCluster();
    }
  }

  /**
   * Test, on a local filesystem, that the FileLink is still readable
View Full Code Here

        }
      } finally {
        in.close();
      }
    } finally {
      testUtil.shutdownMiniCluster();
    }
  }

  /**
   * Write up to 'size' bytes with value 'v' into a new file called 'path'.
View Full Code Here

          6, regions.size());
    assertTrue("The table should be in enabled state", cluster.getMaster()
        .getAssignmentManager().getTableStateManager()
        .isTableState(TableName.valueOf("tableRestart"), ZooKeeperProtos.Table.State.ENABLED));
    ht.close();
    TEST_UTIL.shutdownMiniCluster();
  }

  private void log(String msg) {
    LOG.debug("\n\nTRR: " + msg + "\n");
  }
View Full Code Here

TOP
Copyright © 2018 www.massapi.com. 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.