Java 类org.apache.hadoop.hbase.ipc.HMasterInterface 实例源码

项目:LCIndex-HBase-0.94.16    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:LCIndex-HBase-0.94.16    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:LCIndex-HBase-0.94.16    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:LCIndex-HBase-0.94.16    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:IRIndex    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:IRIndex    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:IRIndex    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:IRIndex    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:RStore    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:RStore    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:HBase-Research    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:HBase-Research    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:HBase-Research    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:HBase-Research    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:hbase-0.94.8-qod    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:hbase-0.94.8-qod    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:hbase-0.94.8-qod    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:hbase-0.94.8-qod    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:hbase-0.94.8-qod    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:hbase-0.94.8-qod    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:hbase-0.94.8-qod    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:hbase-0.94.8-qod    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:hindex    文件:HMaster.java   
@Override
public ProtocolSignature getProtocolSignature(
    String protocol, long version, int clientMethodsHashCode)
throws IOException {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterInterface.VERSION, null);
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return new ProtocolSignature(HMasterRegionInterface.VERSION, null);
  }
  throw new IOException("Unknown protocol: " + protocol);
}
项目:hindex    文件:HMaster.java   
public long getProtocolVersion(String protocol, long clientVersion) {
  if (HMasterInterface.class.getName().equals(protocol)) {
    return HMasterInterface.VERSION;
  } else if (HMasterRegionInterface.class.getName().equals(protocol)) {
    return HMasterRegionInterface.VERSION;
  }
  // unknown protocol
  LOG.warn("Version requested for unimplemented protocol: "+protocol);
  return -1;
}
项目:hindex    文件:TestSnapshotFromAdmin.java   
/**
 * Make sure that we validate the snapshot name and the table name before we pass anything across
 * the wire
 * @throws Exception on failure
 */
@Test
public void testValidateSnapshotName() throws Exception {
  HConnectionManager.HConnectionImplementation mockConnection = Mockito
      .mock(HConnectionManager.HConnectionImplementation.class);
  Configuration conf = HBaseConfiguration.create();
  Mockito.when(mockConnection.getConfiguration()).thenReturn(conf);
  HBaseAdmin admin = new HBaseAdmin(mockConnection);
  SnapshotDescription.Builder builder = SnapshotDescription.newBuilder();
  // check that invalid snapshot names fail
  failSnapshotStart(admin, builder.setName(HConstants.SNAPSHOT_DIR_NAME).build());
  failSnapshotStart(admin, builder.setName("-snapshot").build());
  failSnapshotStart(admin, builder.setName("snapshot fails").build());
  failSnapshotStart(admin, builder.setName("snap$hot").build());
  // check the table name also get verified
  failSnapshotStart(admin, builder.setName("snapshot").setTable(".table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("-table").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("table fails").build());
  failSnapshotStart(admin, builder.setName("snapshot").setTable("tab%le").build());

  // mock the master connection
  HMasterInterface master = Mockito.mock(HMasterInterface.class);
  Mockito.when(mockConnection.getMaster()).thenReturn(master);

  Mockito.when(
    master.snapshot(Mockito.any(HSnapshotDescription.class))).thenReturn((long)0);
  Mockito.when(
    master.isSnapshotDone(
      Mockito.any(HSnapshotDescription.class))).thenReturn(true);

    // make sure that we can use valid names
  admin.snapshot(builder.setName("snapshot").setTable("table").build());
}
项目:hindex    文件:TestHMasterRPCException.java   
@Test
public void testRPCException() throws Exception {
  HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();
  TEST_UTIL.startMiniZKCluster();
  Configuration conf = TEST_UTIL.getConfiguration();
  conf.set(HConstants.MASTER_PORT, "0");

  HMaster hm = new HMaster(conf);

  ServerName sm = hm.getServerName();
  InetSocketAddress isa = new InetSocketAddress(sm.getHostname(), sm.getPort());
  RpcEngine rpcEngine = null;
  try {
    rpcEngine = HBaseRPC.getProtocolEngine(conf);
    HMasterInterface inf = rpcEngine.getProxy(
        HMasterInterface.class,  HMasterInterface.VERSION, isa, conf, 100 * 10);
    inf.isMasterRunning();
    fail();
  } catch (RemoteException ex) {
    assertTrue(ex.getMessage().startsWith(
        "org.apache.hadoop.hbase.ipc.ServerNotRunningYetException: Server is not running yet"));
  } catch (Throwable t) {
    fail("Unexpected throwable: " + t);
  } finally {
    if (rpcEngine != null) {
      rpcEngine.close();
    }
  }
}
项目:LCIndex-HBase-0.94.16    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:LCIndex-HBase-0.94.16    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}
项目:IRIndex    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:IRIndex    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}
项目:RStore    文件:HMaster.java   
/**
 * Initializes the HMaster. The steps are as follows:
 * <p>
 * <ol>
 * <li>Initialize HMaster RPC and address
 * <li>Connect to ZooKeeper.
 * </ol>
 * <p>
 * Remaining steps of initialization occur in {@link #run()} so that they
 * run in their own thread rather than within the context of the constructor.
 * @throws InterruptedException
 */
public HMaster(final Configuration conf)
throws IOException, KeeperException, InterruptedException {
  this.conf = new Configuration(conf);
  // Disable the block cache on the master
  this.conf.setFloat(HConstants.HFILE_BLOCK_CACHE_SIZE_KEY, 0.0f);
  // Set how many times to retry talking to another server over HConnection.
  HConnectionManager.setServerSideHConnectionRetries(this.conf, LOG);
  // Server to handle client requests.
  String hostname = DNS.getDefaultHost(
    conf.get("hbase.master.dns.interface", "default"),
    conf.get("hbase.master.dns.nameserver", "default"));
  int port = conf.getInt(HConstants.MASTER_PORT, HConstants.DEFAULT_MASTER_PORT);
  // Creation of a HSA will force a resolve.
  InetSocketAddress initialIsa = new InetSocketAddress(hostname, port);
  if (initialIsa.getAddress() == null) {
    throw new IllegalArgumentException("Failed resolve of " + this.isa);
  }
  int numHandlers = conf.getInt("hbase.master.handler.count",
    conf.getInt("hbase.regionserver.handler.count", 25));
  this.rpcServer = HBaseRPC.getServer(this,
    new Class<?>[]{HMasterInterface.class, HMasterRegionInterface.class},
      initialIsa.getHostName(), // BindAddress is IP we got for this server.
      initialIsa.getPort(),
      numHandlers,
      0, // we dont use high priority handlers in master
      conf.getBoolean("hbase.rpc.verbose", false), conf,
      0); // this is a DNC w/o high priority handlers
  // Set our address.
  this.isa = this.rpcServer.getListenerAddress();
  this.serverName = new ServerName(this.isa.getHostName(),
    this.isa.getPort(), System.currentTimeMillis());
  this.rsFatals = new MemoryBoundedLogMessageBuffer(
      conf.getLong("hbase.master.buffer.for.rs.fatals", 1*1024*1024));

  // initialize server principal (if using secure Hadoop)
  User.login(conf, "hbase.master.keytab.file",
    "hbase.master.kerberos.principal", this.isa.getHostName());

  // set the thread name now we have an address
  setName(MASTER + "-" + this.serverName.toString());

  Replication.decorateMasterConfiguration(this.conf);

  // Hack! Maps DFSClient => Master for logs.  HDFS made this
  // config param for task trackers, but we can piggyback off of it.
  if (this.conf.get("mapred.task.id") == null) {
    this.conf.set("mapred.task.id", "hb_m_" + this.serverName.toString());
  }

  this.zooKeeper = new ZooKeeperWatcher(conf, MASTER + ":" + isa.getPort(), this, true);
  this.rpcServer.startThreads();
  this.metrics = new MasterMetrics(getServerName().toString());
}
项目:HBase-Research    文件:HMaster.java   
/**
 * Initializes the HMaster. The steps are as follows:
 * <p>
 * <ol>
 * <li>Initialize HMaster RPC and address
 * <li>Connect to ZooKeeper.
 * </ol>
 * <p>
 * Remaining steps of initialization occur in {@link #run()} so that they
 * run in their own thread rather than within the context of the constructor.
 * @throws InterruptedException
 */
public HMaster(final Configuration conf)
throws IOException, KeeperException, InterruptedException {
  this.conf = new Configuration(conf);
  // Disable the block cache on the master
  this.conf.setFloat(HConstants.HFILE_BLOCK_CACHE_SIZE_KEY, 0.0f);
  // Set how many times to retry talking to another server over HConnection.
  HConnectionManager.setServerSideHConnectionRetries(this.conf, LOG);
  // Server to handle client requests.
  String hostname = conf.get("hbase.master.ipc.address",
    Strings.domainNamePointerToHostName(DNS.getDefaultHost(
      conf.get("hbase.master.dns.interface", "default"),
      conf.get("hbase.master.dns.nameserver", "default"))));
  int port = conf.getInt(HConstants.MASTER_PORT, HConstants.DEFAULT_MASTER_PORT);
  // Test that the hostname is reachable
  InetSocketAddress initialIsa = new InetSocketAddress(hostname, port);
  if (initialIsa.getAddress() == null) {
    throw new IllegalArgumentException("Failed resolve of hostname " + initialIsa);
  }
  int numHandlers = conf.getInt("hbase.master.handler.count",
    conf.getInt("hbase.regionserver.handler.count", 25));
  this.rpcServer = HBaseRPC.getServer(this,
    new Class<?>[]{HMasterInterface.class, HMasterRegionInterface.class},
      initialIsa.getHostName(), // This is bindAddress if set else it's hostname
      initialIsa.getPort(),
      numHandlers,
      0, // we dont use high priority handlers in master
      conf.getBoolean("hbase.rpc.verbose", false), conf,
      0); // this is a DNC w/o high priority handlers
  // Set our address.
  this.isa = this.rpcServer.getListenerAddress();
  this.serverName = new ServerName(this.isa.getHostName(),
    this.isa.getPort(), System.currentTimeMillis());
  this.rsFatals = new MemoryBoundedLogMessageBuffer(
      conf.getLong("hbase.master.buffer.for.rs.fatals", 1*1024*1024));

  // login the zookeeper client principal (if using security)
  ZKUtil.loginClient(this.conf, "hbase.zookeeper.client.keytab.file",
    "hbase.zookeeper.client.kerberos.principal", this.isa.getHostName());

  // initialize server principal (if using secure Hadoop)
  User.login(conf, "hbase.master.keytab.file",
    "hbase.master.kerberos.principal", this.isa.getHostName());

  // set the thread name now we have an address
  setName(MASTER + "-" + this.serverName.toString());

  Replication.decorateMasterConfiguration(this.conf);

  // Hack! Maps DFSClient => Master for logs.  HDFS made this
  // config param for task trackers, but we can piggyback off of it.
  if (this.conf.get("mapred.task.id") == null) {
    this.conf.set("mapred.task.id", "hb_m_" + this.serverName.toString());
  }

  this.zooKeeper = new ZooKeeperWatcher(conf, MASTER + ":" + isa.getPort(), this, true);
  this.rpcServer.startThreads();
  this.metrics = new MasterMetrics(getServerName().toString());

  // Health checker thread.
  int sleepTime = this.conf.getInt(HConstants.HEALTH_CHORE_WAKE_FREQ,
    HConstants.DEFAULT_THREAD_WAKE_FREQUENCY);
  if (isHealthCheckerConfigured()) {
    healthCheckChore = new HealthCheckChore(sleepTime, this, getConfiguration());
  }

  this.shouldSplitMetaSeparately = conf.getBoolean(HLog.SEPARATE_HLOG_FOR_META, false);
  waitingOnLogSplitting = this.conf.getBoolean("hbase.master.wait.for.log.splitting", false);
}
项目:HBase-Research    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:HBase-Research    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}
项目:hbase-0.94.8-qod    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:hbase-0.94.8-qod    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}
项目:hbase-0.94.8-qod    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:hbase-0.94.8-qod    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}
项目:hindex    文件:MiniHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() {
  return this.hbaseCluster.getActiveMaster();
}
项目:hindex    文件:DistributedHBaseCluster.java   
@Override
public HMasterInterface getMasterAdmin() throws IOException {
  HConnection conn = HConnectionManager.getConnection(conf);
  return conn.getMaster();
}