Package org.apache.hadoop.hbase.snapshot

Examples of org.apache.hadoop.hbase.snapshot.SnapshotLogSplitter$LogWriter


   * Split and verify test logs for the specified table
   */
  private void splitTestLogs(final byte[] tableName, final Map<byte[], byte[]> regionsMap)
      throws IOException {
    Path tableDir = new Path(TEST_UTIL.getDataTestDir(), Bytes.toString(tableName));
    SnapshotLogSplitter logSplitter = new SnapshotLogSplitter(conf, fs, tableDir,
      tableName, regionsMap);
    try {
      logSplitter.splitLog(logFile);
    } finally {
      logSplitter.close();
    }
    verifyRecoverEdits(tableDir, tableName, regionsMap);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.snapshot.SnapshotLogSplitter$LogWriter

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.