Class TestClientNoCluster.RegionServerStoppedOnScannerOpenConnection

java.lang.Object
org.apache.hadoop.hbase.client.ConnectionImplementation
org.apache.hadoop.hbase.client.TestClientNoCluster.RegionServerStoppedOnScannerOpenConnection
All Implemented Interfaces:
Closeable, AutoCloseable, org.apache.hadoop.hbase.Abortable, org.apache.hadoop.hbase.client.ClusterConnection, org.apache.hadoop.hbase.client.Connection
Enclosing class:
TestClientNoCluster

static class TestClientNoCluster.RegionServerStoppedOnScannerOpenConnection extends org.apache.hadoop.hbase.client.ConnectionImplementation
Override to shutdown going to zookeeper for cluster id and meta location.
  • Nested Class Summary

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.client.ConnectionImplementation

    org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState, org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    (package private) final org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
     

    Fields inherited from class org.apache.hadoop.hbase.client.ConnectionImplementation

    clusterId, clusterStatusListener, MASTER_STATE_CACHE_TIMEOUT_SEC, masterServiceState, RETRIES_BY_SERVER_KEY, rpcTimeout, user

    Fields inherited from interface org.apache.hadoop.hbase.client.ClusterConnection

    HBASE_CLIENT_CONNECTION_IMPL
  • Constructor Summary

    Constructors
    Constructor
    Description
    RegionServerStoppedOnScannerOpenConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user, Map<String,byte[]> requestAttributes)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
    getClient(org.apache.hadoop.hbase.ServerName sn)
     

    Methods inherited from class org.apache.hadoop.hbase.client.ConnectionImplementation

    abort, cacheLocation, clearCaches, clearRegionCache, clearRegionCache, clearRegionLocationCache, close, finalize, getAdmin, getAdmin, getAdminForMaster, getAllBootstrapNodes, getAsyncProcess, getBackoffPolicy, getBufferedMutator, getBufferedMutator, getCachedLocation, getChoreService, getClusterId, getConfiguration, getConnectionConfiguration, getConnectionMetrics, getConnectionRegistry, getCurrentBatchPool, getCurrentMetaLookupPool, getHbck, getHbck, getLiveRegionServers, getMaster, getMasterServiceState, getNewRpcRetryingCallerFactory, getNonceGenerator, getNumberOfCachedRegionLocations, getRegionLocation, getRegionLocator, getRpcClient, getRpcControllerFactory, getRpcRetryingCallerFactory, getStatisticsTracker, getTable, getTableBuilder, getTableState, getUser, hasCellBlockSupport, injectNonceGeneratorForTesting, isAborted, isClosed, isMasterRunning, isTableAvailable, isTableDisabled, isTableEnabled, locateRegion, locateRegion, locateRegion, locateRegion, locateRegions, locateRegions, masterConnectionStateSupplier, releaseMaster, relocateRegion, relocateRegion, retrieveClusterId, takeUserRegionLock, toString, updateCachedLocation, updateCachedLocations

    Methods inherited from class java.lang.Object

    clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait

    Methods inherited from interface org.apache.hadoop.hbase.Abortable

    abort

    Methods inherited from interface org.apache.hadoop.hbase.client.ClusterConnection

    clearRegionCache

    Methods inherited from interface org.apache.hadoop.hbase.client.Connection

    getTable
  • Field Details

    • stub

      final org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface stub
  • Constructor Details

  • Method Details

    • getClient

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(org.apache.hadoop.hbase.ServerName sn) throws IOException
      Specified by:
      getClient in interface org.apache.hadoop.hbase.client.ClusterConnection
      Overrides:
      getClient in class org.apache.hadoop.hbase.client.ConnectionImplementation
      Throws:
      IOException