当前位置: 首页>>代码示例>>Java>>正文


Java RegionServerStoppedException类代码示例

本文整理汇总了Java中org.apache.hadoop.hbase.regionserver.RegionServerStoppedException的典型用法代码示例。如果您正苦于以下问题:Java RegionServerStoppedException类的具体用法?Java RegionServerStoppedException怎么用?Java RegionServerStoppedException使用的例子?那么, 这里精选的类代码示例或许可以为您提供帮助。


RegionServerStoppedException类属于org.apache.hadoop.hbase.regionserver包,在下文中一共展示了RegionServerStoppedException类的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: getAdmin

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
// Nothing is done w/ the 'master' parameter.  It is ignored.
public AdminService.BlockingInterface getAdmin(final ServerName serverName,
  final boolean master)
throws IOException {
  if (isDeadServer(serverName)) {
    throw new RegionServerStoppedException(serverName + " is dead.");
  }
  String key = getStubKey(AdminService.BlockingInterface.class.getName(),
      serverName.getHostname(), serverName.getPort(), this.hostnamesCanChange);
  this.connectionLock.putIfAbsent(key, key);
  AdminService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (AdminService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel =
          this.rpcClient.createBlockingRpcChannel(serverName, user, rpcTimeout);
      stub = AdminService.newBlockingStub(channel);
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:24,代码来源:ConnectionManager.java

示例2: getClient

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
public ClientService.BlockingInterface getClient(final ServerName sn)
throws IOException {
  if (isDeadServer(sn)) {
    throw new RegionServerStoppedException(sn + " is dead.");
  }
  String key = getStubKey(ClientService.BlockingInterface.class.getName(), sn.getHostname(),
      sn.getPort(), this.hostnamesCanChange);
  this.connectionLock.putIfAbsent(key, key);
  ClientService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (ClientService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel =
          this.rpcClient.createBlockingRpcChannel(sn, user, rpcTimeout);
      stub = ClientService.newBlockingStub(channel);
      // In old days, after getting stub/proxy, we'd make a call.  We are not doing that here.
      // Just fail on first actual call rather than in here on setup.
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:24,代码来源:ConnectionManager.java

示例3: ScanOpenNextThenExceptionThenRecoverConnection

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
ScanOpenNextThenExceptionThenRecoverConnection(Configuration conf,
    boolean managed, ExecutorService pool) throws IOException {
  super(conf, managed);
  // Mock up my stub so open scanner returns a scanner id and then on next, we throw
  // exceptions for three times and then after that, we return no more to scan.
  this.stub = Mockito.mock(ClientService.BlockingInterface.class);
  long sid = 12345L;
  try {
    Mockito.when(stub.scan((RpcController)Mockito.any(),
        (ClientProtos.ScanRequest)Mockito.any())).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).build()).
      thenThrow(new ServiceException(new RegionServerStoppedException("From Mockito"))).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).
          setMoreResults(false).build());
  } catch (ServiceException e) {
    throw new IOException(e);
  }
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:19,代码来源:TestClientNoCluster.java

示例4: RegionServerStoppedOnScannerOpenConnection

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
RegionServerStoppedOnScannerOpenConnection(Configuration conf, boolean managed,
    ExecutorService pool, User user) throws IOException {
  super(conf, managed);
  // Mock up my stub so open scanner returns a scanner id and then on next, we throw
  // exceptions for three times and then after that, we return no more to scan.
  this.stub = Mockito.mock(ClientService.BlockingInterface.class);
  long sid = 12345L;
  try {
    Mockito.when(stub.scan((RpcController)Mockito.any(),
        (ClientProtos.ScanRequest)Mockito.any())).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).build()).
      thenThrow(new ServiceException(new RegionServerStoppedException("From Mockito"))).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).
          setMoreResults(false).build());
  } catch (ServiceException e) {
    throw new IOException(e);
  }
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:19,代码来源:TestClientNoCluster.java

示例5: getAdmin

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
// Nothing is done w/ the 'master' parameter.  It is ignored.
public AdminService.BlockingInterface getAdmin(final ServerName serverName,
                                               final boolean master)
        throws IOException {
    if (isDeadServer(serverName)) {
        throw new RegionServerStoppedException(serverName + " is dead.");
    }
    String key = getStubKey(AdminService.BlockingInterface.class.getName(),
            serverName.getHostAndPort());
    this.connectionLock.putIfAbsent(key, key);
    AdminService.BlockingInterface stub = null;
    synchronized (this.connectionLock.get(key)) {
        stub = (AdminService.BlockingInterface) this.stubs.get(key);
        if (stub == null) {
            BlockingRpcChannel channel =
                    this.rpcClient.createBlockingRpcChannel(serverName, user, rpcTimeout);
            stub = AdminService.newBlockingStub(channel);
            this.stubs.put(key, stub);
        }
    }
    return stub;
}
 
开发者ID:grokcoder,项目名称:pbase,代码行数:24,代码来源:ConnectionManager.java

示例6: getClient

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
public ClientService.BlockingInterface getClient(final ServerName sn)
        throws IOException {
    if (isDeadServer(sn)) {
        throw new RegionServerStoppedException(sn + " is dead.");
    }
    String key = getStubKey(ClientService.BlockingInterface.class.getName(), sn.getHostAndPort());
    this.connectionLock.putIfAbsent(key, key);
    ClientService.BlockingInterface stub = null;
    synchronized (this.connectionLock.get(key)) {
        stub = (ClientService.BlockingInterface) this.stubs.get(key);
        if (stub == null) {
            BlockingRpcChannel channel =
                    this.rpcClient.createBlockingRpcChannel(sn, user, rpcTimeout);
            stub = ClientService.newBlockingStub(channel);
            // In old days, after getting stub/proxy, we'd make a call.  We are not doing that here.
            // Just fail on first actual call rather than in here on setup.
            this.stubs.put(key, stub);
        }
    }
    return stub;
}
 
开发者ID:grokcoder,项目名称:pbase,代码行数:23,代码来源:ConnectionManager.java

示例7: getAdmin

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
// Nothing is done w/ the 'master' parameter.  It is ignored.
public AdminService.BlockingInterface getAdmin(final ServerName serverName,
  final boolean master)
throws IOException {
  if (isDeadServer(serverName)) {
    throw new RegionServerStoppedException(serverName + " is dead.");
  }
  String key = getStubKey(AdminService.BlockingInterface.class.getName(),
    serverName.getHostAndPort());
  this.connectionLock.putIfAbsent(key, key);
  AdminService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (AdminService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel = this.rpcClient.createBlockingRpcChannel(serverName,
        user, this.rpcTimeout);
      stub = AdminService.newBlockingStub(channel);
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:tenggyut,项目名称:HIndex,代码行数:24,代码来源:HConnectionManager.java

示例8: getClient

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
public ClientService.BlockingInterface getClient(final ServerName sn)
throws IOException {
  if (isDeadServer(sn)) {
    throw new RegionServerStoppedException(sn + " is dead.");
  }
  String key = getStubKey(ClientService.BlockingInterface.class.getName(), sn.getHostAndPort());
  this.connectionLock.putIfAbsent(key, key);
  ClientService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (ClientService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel = this.rpcClient.createBlockingRpcChannel(sn,
        user, this.rpcTimeout);
      stub = ClientService.newBlockingStub(channel);
      // In old days, after getting stub/proxy, we'd make a call.  We are not doing that here.
      // Just fail on first actual call rather than in here on setup.
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:tenggyut,项目名称:HIndex,代码行数:23,代码来源:HConnectionManager.java

示例9: preGetOp

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
public void preGetOp(final ObserverContext<RegionCoprocessorEnvironment> e,
    final Get get, final List<Cell> results) throws IOException {

  int replicaId = e.getEnvironment().getRegion().getRegionInfo().getReplicaId();

  // Fail for the primary replica, but not for meta
  if (throwException) {
    if (!e.getEnvironment().getRegion().getRegionInfo().isMetaRegion() && (replicaId == 0)) {
      LOG.info("Get, throw Region Server Stopped Exceptoin for region " + e.getEnvironment()
          .getRegion().getRegionInfo());
      throw new RegionServerStoppedException("Server " + e.getEnvironment().getServerName()
              + " not running");
    }
  } else {
    LOG.info("Get, We're replica region " + replicaId);
  }
}
 
开发者ID:apache,项目名称:hbase,代码行数:19,代码来源:TestReplicaWithCluster.java

示例10: execCloseRegion

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
protected CloseRegionResponse execCloseRegion(ServerName server, byte[] regionName)
    throws IOException {
  switch (this.invocations++) {
  case 0: throw new NotServingRegionException("Fake");
  case 1: throw new RegionServerAbortedException("Fake!");
  case 2: throw new RegionServerStoppedException("Fake!");
  case 3: throw new ServerNotRunningYetException("Fake!");
  case 4:
    LOG.info("Return null response from serverName=" + server + "; means STUCK...TODO timeout");
    executor.schedule(new Runnable() {
      @Override
      public void run() {
        LOG.info("Sending in CRASH of " + server);
        doCrash(server);
      }
    }, 1, TimeUnit.SECONDS);
    return null;
  default:
    return super.execCloseRegion(server, regionName);
  }
}
 
开发者ID:apache,项目名称:hbase,代码行数:23,代码来源:TestAssignmentManager.java

示例11: RegionServerStoppedOnScannerOpenConnection

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
RegionServerStoppedOnScannerOpenConnection(Configuration conf,
    ExecutorService pool, User user) throws IOException {
  super(conf, pool, user);
  // Mock up my stub so open scanner returns a scanner id and then on next, we throw
  // exceptions for three times and then after that, we return no more to scan.
  this.stub = Mockito.mock(ClientService.BlockingInterface.class);
  long sid = 12345L;
  try {
    Mockito.when(stub.scan((RpcController)Mockito.any(),
        (ClientProtos.ScanRequest)Mockito.any())).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).build()).
      thenThrow(new ServiceException(new RegionServerStoppedException("From Mockito"))).
      thenReturn(ClientProtos.ScanResponse.newBuilder().setScannerId(sid).
          setMoreResults(false).build());
  } catch (ServiceException e) {
    throw new IOException(e);
  }
}
 
开发者ID:apache,项目名称:hbase,代码行数:19,代码来源:TestClientNoCluster.java

示例12: getAdmin

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
// Nothing is done w/ the 'master' parameter.  It is ignored.
public AdminService.BlockingInterface getAdmin(final ServerName serverName,
  final boolean master)
throws IOException {
  if (isDeadServer(serverName)) {
    throw new RegionServerStoppedException(serverName + " is dead.");
  }
  String key = getStubKey(AdminService.BlockingInterface.class.getName(),
    serverName.getHostAndPort());
  this.connectionLock.putIfAbsent(key, key);
  AdminService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (AdminService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel =
          this.rpcClient.createBlockingRpcChannel(serverName, user, rpcTimeout);
      stub = AdminService.newBlockingStub(channel);
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:shenli-uiuc,项目名称:PyroDB,代码行数:24,代码来源:ConnectionManager.java

示例13: getClient

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
public ClientService.BlockingInterface getClient(final ServerName sn)
throws IOException {
  if (isDeadServer(sn)) {
    throw new RegionServerStoppedException(sn + " is dead.");
  }
  String key = getStubKey(ClientService.BlockingInterface.class.getName(), sn.getHostAndPort());
  this.connectionLock.putIfAbsent(key, key);
  ClientService.BlockingInterface stub = null;
  synchronized (this.connectionLock.get(key)) {
    stub = (ClientService.BlockingInterface)this.stubs.get(key);
    if (stub == null) {
      BlockingRpcChannel channel =
          this.rpcClient.createBlockingRpcChannel(sn, user, rpcTimeout);
      stub = ClientService.newBlockingStub(channel);
      // In old days, after getting stub/proxy, we'd make a call.  We are not doing that here.
      // Just fail on first actual call rather than in here on setup.
      this.stubs.put(key, stub);
    }
  }
  return stub;
}
 
开发者ID:shenli-uiuc,项目名称:PyroDB,代码行数:23,代码来源:ConnectionManager.java

示例14: RpcTimeoutConnection

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
RpcTimeoutConnection(Configuration conf, boolean managed, ExecutorService pool, User user)
throws IOException {
  super(conf, managed);
  // Mock up my stub so an exists call -- which turns into a get -- throws an exception
  this.stub = Mockito.mock(ClientService.BlockingInterface.class);
  try {
    Mockito.when(stub.get((RpcController)Mockito.any(),
        (ClientProtos.GetRequest)Mockito.any())).
      thenThrow(new ServiceException(new RegionServerStoppedException("From Mockito")));
  } catch (ServiceException e) {
    throw new IOException(e);
  }
}
 
开发者ID:fengchen8086,项目名称:ditb,代码行数:14,代码来源:TestClientNoCluster.java

示例15: remoteCallFailed

import org.apache.hadoop.hbase.regionserver.RegionServerStoppedException; //导入依赖的package包/类
@Override
protected boolean remoteCallFailed(final MasterProcedureEnv env, final RegionStateNode regionNode,
    final IOException exception) {
  // TODO: Is there on-going rpc to cleanup?
  if (exception instanceof ServerCrashException) {
    // This exception comes from ServerCrashProcedure after log splitting.
    // SCP found this region as a RIT. Its call into here says it is ok to let this procedure go
    // on to a complete close now. This will release lock on this region so subsequent action on
    // region can succeed; e.g. the assign that follows this unassign when a move (w/o wait on SCP
    // the assign could run w/o logs being split so data loss).
    try {
      reportTransition(env, regionNode, TransitionCode.CLOSED, HConstants.NO_SEQNUM);
    } catch (UnexpectedStateException e) {
      // Should never happen.
      throw new RuntimeException(e);
    }
  } else if (exception instanceof RegionServerAbortedException ||
      exception instanceof RegionServerStoppedException ||
      exception instanceof ServerNotRunningYetException) {
    // TODO
    // RS is aborting, we cannot offline the region since the region may need to do WAL
    // recovery. Until we see the RS expiration, we should retry.
    // TODO: This should be suspend like the below where we call expire on server?
    LOG.info("Ignoring; waiting on ServerCrashProcedure", exception);
  } else if (exception instanceof NotServingRegionException) {
    LOG.info("IS THIS OK? ANY LOGS TO REPLAY; ACTING AS THOUGH ALL GOOD " + regionNode,
      exception);
    setTransitionState(RegionTransitionState.REGION_TRANSITION_FINISH);
  } else {
    LOG.warn("Expiring server " + this + "; " + regionNode.toShortString() +
      ", exception=" + exception);
    env.getMasterServices().getServerManager().expireServer(regionNode.getRegionLocation());
    // Return false so this procedure stays in suspended state. It will be woken up by a
    // ServerCrashProcedure when it notices this RIT.
    // TODO: Add a SCP as a new subprocedure that we now come to depend on.
    return false;
  }
  return true;
}
 
开发者ID:apache,项目名称:hbase,代码行数:40,代码来源:UnassignProcedure.java


注:本文中的org.apache.hadoop.hbase.regionserver.RegionServerStoppedException类示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。