Java 类org.apache.hadoop.hbase.master.metrics.MasterMetrics 实例源码

项目:LCIndex-HBase-0.94.16    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  long wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long timeoutMillis = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, opThreads);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool, timeoutMillis, wakeFrequency);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:LCIndex-HBase-0.94.16    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:LCIndex-HBase-0.94.16    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:LCIndex-HBase-0.94.16    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor = new ForeignExceptionDispatcher(snapshot.getName());

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:IRIndex    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  long wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long timeoutMillis = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, opThreads);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool, timeoutMillis, wakeFrequency);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:IRIndex    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:IRIndex    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:IRIndex    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor = new ForeignExceptionDispatcher(snapshot.getName());

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:HBase-Research    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  this.wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long keepAliveTime = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, keepAliveTime, opThreads, wakeFrequency);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:HBase-Research    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.wakeFrequency = master.getConfiguration().getInt(SNAPSHOT_WAKE_MILLIS_KEY,
    SNAPSHOT_WAKE_MILLIS_DEFAULT);
  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:HBase-Research    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:HBase-Research    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:HBase-Research    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor =  new ForeignExceptionDispatcher();

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:hbase-0.94.8-qod    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  this.wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long keepAliveTime = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, keepAliveTime, opThreads, wakeFrequency);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:hbase-0.94.8-qod    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.wakeFrequency = master.getConfiguration().getInt(SNAPSHOT_WAKE_MILLIS_KEY,
    SNAPSHOT_WAKE_MILLIS_DEFAULT);
  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:hbase-0.94.8-qod    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:hbase-0.94.8-qod    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:hbase-0.94.8-qod    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor =  new ForeignExceptionDispatcher();

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:hbase-0.94.8-qod    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  this.wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long keepAliveTime = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, keepAliveTime, opThreads, wakeFrequency);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:hbase-0.94.8-qod    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.wakeFrequency = master.getConfiguration().getInt(SNAPSHOT_WAKE_MILLIS_KEY,
    SNAPSHOT_WAKE_MILLIS_DEFAULT);
  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:hbase-0.94.8-qod    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:hbase-0.94.8-qod    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:hbase-0.94.8-qod    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor =  new ForeignExceptionDispatcher();

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:hindex    文件:SnapshotManager.java   
/**
 * Construct a snapshot manager.
 * @param master
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster)
    throws KeeperException, IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  // get the configuration for the coordinator
  Configuration conf = master.getConfiguration();
  this.wakeFrequency = conf.getInt(SNAPSHOT_WAKE_MILLIS_KEY, SNAPSHOT_WAKE_MILLIS_DEFAULT);
  long keepAliveTime = conf.getLong(SNAPSHOT_TIMEOUT_MILLIS_KEY, SNAPSHOT_TIMEOUT_MILLIS_DEFAULT);
  int opThreads = conf.getInt(SNAPSHOT_POOL_THREADS_KEY, SNAPSHOT_POOL_THREADS_DEFAULT);

  // setup the default procedure coordinator
  String name = master.getServerName().toString();
  ThreadPoolExecutor tpool = ProcedureCoordinator.defaultPool(name, keepAliveTime, opThreads, wakeFrequency);
  ProcedureCoordinatorRpcs comms = new ZKProcedureCoordinatorRpcs(
      master.getZooKeeper(), SnapshotManager.ONLINE_SNAPSHOT_CONTROLLER_DESCRIPTION, name);
  this.coordinator = new ProcedureCoordinator(comms, tpool);
  this.executorService = master.getExecutorService();
  resetTempDir();
}
项目:hindex    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.wakeFrequency = master.getConfiguration().getInt(SNAPSHOT_WAKE_MILLIS_KEY,
    SNAPSHOT_WAKE_MILLIS_DEFAULT);
  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:hindex    文件:RestoreSnapshotHandler.java   
public RestoreSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor htd,
    final MasterMetrics metricsMaster) throws IOException {
  super(EventType.C_M_RESTORE_SNAPSHOT, htd.getName(), masterServices, masterServices);
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();

  // Check table exists.
  getTableDescriptor();

  // This is the new schema we are going to write out as this modification.
  this.hTableDescriptor = htd;

  this.status = TaskMonitor.get().createStatus(
    "Restoring  snapshot '" + snapshot.getName() + "' to table "
        + hTableDescriptor.getNameAsString());
}
项目:hindex    文件:CloneSnapshotHandler.java   
public CloneSnapshotHandler(final MasterServices masterServices,
    final SnapshotDescription snapshot, final HTableDescriptor hTableDescriptor,
    final MasterMetrics metricsMaster)
    throws NotAllMetaRegionsOnlineException, TableExistsException, IOException {
  super(masterServices, masterServices.getMasterFileSystem(),
    masterServices.getServerManager(), hTableDescriptor,
    masterServices.getConfiguration(), null, masterServices.getCatalogTracker(),
    masterServices.getAssignmentManager());
  this.metricsMaster = metricsMaster;

  // Snapshot information
  this.snapshot = snapshot;

  // Monitor
  this.monitor = new ForeignExceptionDispatcher();
  this.status = TaskMonitor.get().createStatus("Cloning  snapshot '" + snapshot.getName() +
    "' to table " + hTableDescriptor.getNameAsString());
}
项目:hindex    文件:TakeSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public TakeSnapshotHandler(SnapshotDescription snapshot, final MasterServices masterServices,
    final MasterMetrics metricsMaster) {
  super(masterServices, EventType.C_M_SNAPSHOT_TABLE);
  assert snapshot != null : "SnapshotDescription must not be nul1";
  assert masterServices != null : "MasterServices must not be nul1";

  this.master = masterServices;
  this.metricsMaster = metricsMaster;
  this.snapshot = snapshot;
  this.conf = this.master.getConfiguration();
  this.fs = this.master.getMasterFileSystem().getFileSystem();
  this.rootDir = this.master.getMasterFileSystem().getRootDir();
  this.snapshotDir = SnapshotDescriptionUtils.getCompletedSnapshotDir(snapshot, rootDir);
  this.workingDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  this.monitor =  new ForeignExceptionDispatcher();

  // prepare the verify
  this.verifier = new MasterSnapshotVerifier(masterServices, snapshot, rootDir);
  // update the running tasks
  this.status = TaskMonitor.get().createStatus(
    "Taking " + snapshot.getType() + " snapshot on table: " + snapshot.getTable());
}
项目:LCIndex-HBase-0.94.16    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics, boolean masterRecovery)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  this.tempdir = new Path(this.rootdir, HConstants.HBASE_TEMP_DIRECTORY);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  // make sure the fs has the same conf
  fs.setConf(conf);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, this.services, master.getServerName().toString());
    this.splitLogManager.finishInitialization(masterRecovery);
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}
项目:LCIndex-HBase-0.94.16    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:LCIndex-HBase-0.94.16    文件:DisabledTableSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public DisabledTableSnapshotHandler(SnapshotDescription snapshot,
    final MasterServices masterServices, final MasterMetrics metricsMaster) {
  super(snapshot, masterServices, metricsMaster);

  // setup the timer
  timeoutInjector = TakeSnapshotUtils.getMasterTimerAndBindToMonitor(snapshot, conf, monitor);
}
项目:IRIndex    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics, boolean masterRecovery)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  this.tempdir = new Path(this.rootdir, HConstants.HBASE_TEMP_DIRECTORY);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  // make sure the fs has the same conf
  fs.setConf(conf);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, this.services, master.getServerName().toString());
    this.splitLogManager.finishInitialization(masterRecovery);
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}
项目:IRIndex    文件:SnapshotManager.java   
/**
 * Fully specify all necessary components of a snapshot manager. Exposed for testing.
 * @param master services for the master where the manager is running
 * @param coordinator procedure coordinator instance.  exposed for testing.
 * @param pool HBase ExecutorServcie instance, exposed for testing.
 */
public SnapshotManager(final MasterServices master, final MasterMetrics metricsMaster,
    ProcedureCoordinator coordinator, ExecutorService pool)
    throws IOException, UnsupportedOperationException {
  this.master = master;
  this.metricsMaster = metricsMaster;

  this.rootDir = master.getMasterFileSystem().getRootDir();
  checkSnapshotSupport(master.getConfiguration(), master.getMasterFileSystem());

  this.coordinator = coordinator;
  this.executorService = pool;
  resetTempDir();
}
项目:IRIndex    文件:DisabledTableSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public DisabledTableSnapshotHandler(SnapshotDescription snapshot,
    final MasterServices masterServices, final MasterMetrics metricsMaster) {
  super(snapshot, masterServices, metricsMaster);

  // setup the timer
  timeoutInjector = TakeSnapshotUtils.getMasterTimerAndBindToMonitor(snapshot, conf, monitor);
}
项目:RStore    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, master.getServerName().toString());
    this.splitLogManager.finishInitialization();
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}
项目:HBase-Research    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics, boolean masterRecovery)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  this.tempdir = new Path(this.rootdir, HConstants.HBASE_TEMP_DIRECTORY);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  // make sure the fs has the same conf
  fs.setConf(conf);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, this.services, master.getServerName().toString());
    this.splitLogManager.finishInitialization(masterRecovery);
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}
项目:HBase-Research    文件:DisabledTableSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public DisabledTableSnapshotHandler(SnapshotDescription snapshot,
    final MasterServices masterServices, final MasterMetrics metricsMaster) {
  super(snapshot, masterServices, metricsMaster);

  // setup the timer
  timeoutInjector = TakeSnapshotUtils.getMasterTimerAndBindToMonitor(snapshot, conf, monitor);
}
项目:hbase-0.94.8-qod    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics, boolean masterRecovery)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  this.tempdir = new Path(this.rootdir, HConstants.HBASE_TEMP_DIRECTORY);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  // make sure the fs has the same conf
  fs.setConf(conf);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, this.services, master.getServerName().toString());
    this.splitLogManager.finishInitialization(masterRecovery);
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}
项目:hbase-0.94.8-qod    文件:DisabledTableSnapshotHandler.java   
/**
 * @param snapshot descriptor of the snapshot to take
 * @param masterServices master services provider
 * @throws IOException on unexpected error
 */
public DisabledTableSnapshotHandler(SnapshotDescription snapshot,
    final MasterServices masterServices, final MasterMetrics metricsMaster) {
  super(snapshot, masterServices, metricsMaster);

  // setup the timer
  timeoutInjector = TakeSnapshotUtils.getMasterTimerAndBindToMonitor(snapshot, conf, monitor);
}
项目:hbase-0.94.8-qod    文件:MasterFileSystem.java   
public MasterFileSystem(Server master, MasterServices services,
    MasterMetrics metrics, boolean masterRecovery)
throws IOException {
  this.conf = master.getConfiguration();
  this.master = master;
  this.services = services;
  this.metrics = metrics;
  // Set filesystem to be that of this.rootdir else we get complaints about
  // mismatched filesystems if hbase.rootdir is hdfs and fs.defaultFS is
  // default localfs.  Presumption is that rootdir is fully-qualified before
  // we get to here with appropriate fs scheme.
  this.rootdir = FSUtils.getRootDir(conf);
  this.tempdir = new Path(this.rootdir, HConstants.HBASE_TEMP_DIRECTORY);
  // Cover both bases, the old way of setting default fs and the new.
  // We're supposed to run on 0.20 and 0.21 anyways.
  this.fs = this.rootdir.getFileSystem(conf);
  String fsUri = this.fs.getUri().toString();
  conf.set("fs.default.name", fsUri);
  conf.set("fs.defaultFS", fsUri);
  // make sure the fs has the same conf
  fs.setConf(conf);
  this.distributedLogSplitting =
    conf.getBoolean("hbase.master.distributed.log.splitting", true);
  if (this.distributedLogSplitting) {
    this.splitLogManager = new SplitLogManager(master.getZooKeeper(),
        master.getConfiguration(), master, this.services, master.getServerName().toString());
    this.splitLogManager.finishInitialization(masterRecovery);
  } else {
    this.splitLogManager = null;
  }
  // setup the filesystem variable
  // set up the archived logs path
  this.oldLogDir = createInitialFileSystemLayout();
}