Package org.apache.hadoop.hbase.snapshot

Examples of org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask


        Path regionDir = HRegion.getRegionDir(rootDir, regionInfo);
        new CopyRecoveredEditsTask(snapshot, monitor, fs, regionDir, snapshotRegionDir).call();
        monitor.rethrowException();

        // 2.3 reference all the files in the region
        new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
        monitor.rethrowException();
      }

      // 3. write the table info to disk
      LOG.info("Starting to copy tableinfo for offline snapshot: " +
View Full Code Here


    monitor.rethrowException();
    status.setStatus("Completed copying recovered edits for offline snapshot of table: "
        + snapshot.getTable());

    // 3 reference all the files in the region
    new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
    monitor.rethrowException();
    status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
      snapshot.getTable());
  }
View Full Code Here

    fs.mkdirs(snapshotRegionDir);

    SnapshotDescription snapshot = SnapshotDescription.newBuilder().setName("name")
        .setTable("table").build();
    ForeignExceptionDispatcher monitor = Mockito.mock(ForeignExceptionDispatcher.class);
    ReferenceRegionHFilesTask task = new ReferenceRegionHFilesTask(snapshot, monitor, regionDir,
        fs, snapshotRegionDir);
    ReferenceRegionHFilesTask taskSpy = Mockito.spy(task);
    task.call();

    // make sure we never get an error
    Mockito.verify(taskSpy, Mockito.never()).snapshotFailure(Mockito.anyString(),
        Mockito.any(Exception.class));
View Full Code Here

    monitor.rethrowException();
    status.setStatus("Completed copying recovered edits for offline snapshot of table: "
        + snapshotTable);

    // 2 reference all the files in the region
    new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
    monitor.rethrowException();
    status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
        snapshotTable);
  }
View Full Code Here

        monitor.rethrowException();
        status.setStatus("Completed copying recovered edits for offline snapshot of table: "
            + snapshotTable);

        // 2.3 reference all the files in the region
        new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
        monitor.rethrowException();
        status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
            snapshotTable);
      }
View Full Code Here

        Path snapshotRegionDir = regionFs.getRegionDir();
        new CopyRecoveredEditsTask(snapshot, monitor, fs, regionDir, snapshotRegionDir).call();
        monitor.rethrowException();

        // 2.3 reference all the files in the region
        new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
        monitor.rethrowException();
      }

      // 3. write the table info to disk
      LOG.info("Starting to copy tableinfo for offline snapshot: " +
View Full Code Here

        monitor.rethrowException();
        status.setStatus("Completed copying recovered edits for offline snapshot of table: "
            + snapshot.getTable());

        // 2.3 reference all the files in the region
        new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
        monitor.rethrowException();
        status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
          snapshot.getTable());
      }
View Full Code Here

    monitor.rethrowException();
    status.setStatus("Completed copying recovered edits for offline snapshot of table: "
        + snapshotTable);

    // 2 reference all the files in the region
    new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
    monitor.rethrowException();
    status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
        snapshotTable);
  }
View Full Code Here

        monitor.rethrowException();
        status.setStatus("Completed copying recovered edits for offline snapshot of table: "
            + snapshot.getTable());

        // 2.3 reference all the files in the region
        new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
        monitor.rethrowException();
        status.setStatus("Completed referencing HFiles for offline snapshot of table: " +
          snapshot.getTable());
      }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask

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.