Class TestCreateTableNoRegionServer.HMasterForTest

java.lang.Object
java.lang.Thread
org.apache.hadoop.hbase.HBaseServerBase<org.apache.hadoop.hbase.master.MasterRpcServices>
org.apache.hadoop.hbase.master.HMaster
org.apache.hadoop.hbase.master.procedure.TestCreateTableNoRegionServer.HMasterForTest
All Implemented Interfaces:
Runnable, org.apache.hadoop.hbase.Abortable, org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint, org.apache.hadoop.hbase.conf.ConfigurationObserver, org.apache.hadoop.hbase.master.MasterServices, org.apache.hadoop.hbase.Server, org.apache.hadoop.hbase.Stoppable
Enclosing class:
TestCreateTableNoRegionServer

public static final class TestCreateTableNoRegionServer.HMasterForTest extends org.apache.hadoop.hbase.master.HMaster
  • Nested Class Summary

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.master.HMaster

    org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter

    Nested classes/interfaces inherited from class java.lang.Thread

    Thread.State, Thread.UncaughtExceptionHandler
  • Field Summary

    Fields inherited from class org.apache.hadoop.hbase.master.HMaster

    DEFAULT_HBASE_MASTER_CLEANER_INTERVAL, DEFAULT_HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS, HBASE_MASTER_CLEANER_INTERVAL, HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS, MASTER, WARMUP_BEFORE_MOVE

    Fields inherited from class org.apache.hadoop.hbase.HBaseServerBase

    abortRequested, asyncClusterConnection, choreService, clusterStatusTracker, conf, configurationManager, csm, dataFs, dataRootDir, eventLoopGroupConfig, executorService, infoServer, metaRegionLocationCache, msgInterval, namedQueueRecorder, rpcServices, serverName, sleeper, startcode, stopped, tableDescriptors, userProvider, useThisHostnameInstead, walFs, walRootDir, zooKeeper

    Fields inherited from class java.lang.Thread

    MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
  • Constructor Summary

    Constructors
    Constructor
    Description
    HMasterForTest(org.apache.hadoop.conf.Configuration conf)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.master.assignment.AssignmentManager
     
    private boolean
     

    Methods inherited from class org.apache.hadoop.hbase.master.HMaster

    abort, abortProcedure, addColumn, addReplicationPeer, balance, balance, balanceOrUpdateMetrics, balanceSwitch, cacheTableDescriptor, canCreateBaseZNode, canUpdateTableDescriptor, checkIfShouldMoveSystemRegionAsync, checkServiceStarted, checkTableModifiable, clusterMode, configureInfoServer, constructMaster, createActiveMasterManager, createAssignmentManager, createNamedQueueRecord, createRpcServices, createServerManager, createSystemTable, createTable, decommissionRegionServers, decorateMasterConfiguration, deleteColumn, deleteTable, disableReplicationPeer, disableTable, enableReplicationPeer, enableTable, executeRegionPlansWithThrottling, flushMasterStore, flushTable, getActiveMaster, getActiveMasterInfoPort, getActiveMasterManager, getAverageLoad, getBackupMasterInfoPort, getBackupMasters, getBootstrapNodes, getCatalogJanitor, getClientIdAuditPrefix, getClusterId, getClusterMetrics, getClusterMetrics, getClusterMetricsWithoutCoprocessor, getClusterMetricsWithoutCoprocessor, getClusterSchema, getCompactionState, getCoprocessorHost, getDumpServlet, getFavoredNodesManager, getHbckChore, getHFileCleaner, getHFileCleaners, getInitializedEvent, getLastMajorCompactionTimestamp, getLastMajorCompactionTimestampForRegion, getLiveRegionServers, getLoadBalancer, getLoadBalancerClassName, getLoadedCoprocessors, getLockManager, getLocks, getLogCleaner, getMasterActiveTime, getMasterCoprocessorHost, getMasterCoprocessors, getMasterFileSystem, getMasterFinishedInitializationTime, getMasterMetrics, getMasterProcedureExecutor, getMasterProcedureManagerHost, getMasterQuotaManager, getMasterRegion, getMasterRpcServices, getMasterStartTime, getMasterWalManager, getMetaLocations, getMetaLocationSyncer, getMobCompactionState, getNumWALFiles, getProcedures, getProcedureStore, getProcessName, getQuotaObserverChore, getRegionNormalizerManager, getRegionServerFatalLogBuffer, getRegionServerInfoPort, getRegionServerVersion, getReplicationLoad, getReplicationLogCleanerBarrier, getReplicationPeerConfig, getReplicationPeerManager, getRSGroupInfoManager, getServerManager, getServerName, getSnapshotManager, getSnapshotQuotaObserverChore, getSpaceQuotaSnapshotNotifier, getSplitOrMergeStateStore, getSplitWALManager, getStartupProgress, getSyncReplicationPeerLock, getSyncReplicationReplayWALManager, getTableStateManager, getUseThisHostnameInstead, initClusterSchemaService, isActiveMaster, isBalancerOn, isCatalogJanitorEnabled, isInitialized, isInMaintenanceMode, isNormalizerOn, isOnline, isReplicationPeerModificationEnabled, isSplitOrMergeEnabled, listDecommissionedRegionServers, listNamespaces, listReplicationPeers, listTableDescriptors, listTableDescriptorsByNamespace, listTableNames, listTableNamesByNamespace, login, main, mergeRegions, modifyColumn, modifyColumnStoreFileTracker, modifyTable, modifyTableStoreFileTracker, move, normalizeRegions, onConfigurationChange, recommissionRegionServer, registerService, remoteProcedureCompleted, remoteProcedureFailed, removeReplicationPeer, replicationPeerModificationSwitch, reportMobCompactionEnd, reportMobCompactionStart, restoreSnapshot, run, runReplicationBarrierCleaner, setCatalogJanitorChoreForTesting, setCatalogJanitorEnabled, setHbckChoreForTesting, setInitialized, setServiceStarted, shutdown, skipRegionManagementAction, splitRegion, startProcedureExecutor, stop, stopChores, stopMaster, stopServiceThreads, transitReplicationPeerSyncReplicationState, truncateRegion, truncateTable, updateConfigurationForQuotasObserver, updateReplicationPeerConfig, waitForMetaOnline

    Methods inherited from class org.apache.hadoop.hbase.HBaseServerBase

    closeClusterConnection, closeTableDescriptors, closeZooKeeper, createConnection, getAccessChecker, getAsyncClusterConnection, getChoreService, getConfiguration, getConfigurationManager, getCoordinatedStateManager, getDataRootDir, getEventLoopGroupConfig, getExecutorService, getFileSystem, getInfoServer, getMetaRegionLocationCache, getMsgInterval, getNamedQueueRecorder, getRpcServer, getRpcServices, getStartcode, getTableDescriptors, getWALFileSystem, getWALRootDir, getZKPermissionWatcher, getZooKeeper, initializeFileSystem, initializeMemStoreChunkCreator, installShutdownHook, isAborted, isClusterUp, isShutdownHookInstalled, isStopped, setAbortRequested, setupClusterConnection, shutdownChore, stopChoreService, stopExecutorService, stopInfoServer, toString, updateConfiguration

    Methods inherited from class java.lang.Object

    equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait

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

    abort, isAborted

    Methods inherited from interface org.apache.hadoop.hbase.master.MasterServices

    getAccessChecker, getExecutorService, getTableDescriptors, getZKPermissionWatcher, isClusterUp, modifyTable

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

    createConnection, getAsyncClusterConnection, getAsyncConnection, getChoreService, getConfiguration, getConnection, getCoordinatedStateManager, getFileSystem, getZooKeeper, isStopping

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

    isStopped
  • Constructor Details

  • Method Details

    • isInAssignRegionsState

      private boolean isInAssignRegionsState()
    • getAssignmentManager

      public org.apache.hadoop.hbase.master.assignment.AssignmentManager getAssignmentManager()
      Specified by:
      getAssignmentManager in interface org.apache.hadoop.hbase.master.MasterServices
      Overrides:
      getAssignmentManager in class org.apache.hadoop.hbase.master.HMaster