Class TestAsyncProcess.MyConnectionImpl2

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

Returns our async process.
  • Nested Class Summary

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

    TestAsyncProcess.MyConnectionImpl.TestRegistry

    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) List<org.apache.hadoop.hbase.HRegionLocation>
     
    (package private) final boolean[]
     

    Fields inherited from class org.apache.hadoop.hbase.client.TestAsyncProcess.MyConnectionImpl

    nbThreads

    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
    Modifier
    Constructor
    Description
    protected
    MyConnectionImpl2(List<org.apache.hadoop.hbase.HRegionLocation> hrl, org.apache.hadoop.conf.Configuration conf)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.RegionLocations
    locateRegion(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId)
     

    Methods inherited from class org.apache.hadoop.hbase.client.TestAsyncProcess.MyConnectionImpl

    hasCellBlockSupport

    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, getClient, 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, injectNonceGeneratorForTesting, isAborted, isClosed, isMasterRunning, isTableAvailable, isTableDisabled, isTableEnabled, 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

    • hrl

      List<org.apache.hadoop.hbase.HRegionLocation> hrl
    • usedRegions

      final boolean[] usedRegions
  • Constructor Details

  • Method Details