public static class HMasterCommandLine.LocalHMaster extends HMaster
HMaster.TableDescriptorGetter
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
private MiniZooKeeperCluster |
zkcluster |
catalogJanitorChore, coprocessorServiceHandlers, cpHost, DEFAULT_HBASE_MASTER_CLEANER_INTERVAL, DEFAULT_HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS, HBASE_MASTER_CLEANER_INTERVAL, HBASE_MASTER_WAIT_ON_SERVICE_IN_SECONDS, loadBalancerStateStore, MAINTENANCE_MODE, MASTER, masterAddressSyncer, metricsMaster, rsFatals, serviceStarted, snapshotCleanupStateStore, snapshotManager, WARMUP_BEFORE_MOVE
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
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
LocalHMaster(org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
void |
run() |
(package private) void |
setZKCluster(MiniZooKeeperCluster zkcluster) |
abort, abortProcedure, addColumn, addReplicationPeer, balance, balance, balanceOrUpdateMetrics, balanceSwitch, cacheTableDescriptor, canCreateBaseZNode, canUpdateTableDescriptor, checkIfShouldMoveSystemRegionAsync, checkInitialized, checkServiceStarted, checkTableModifiable, clusterMode, configureInfoServer, constructMaster, createActiveMasterManager, createAssignmentManager, createNamedQueueRecord, createNamespace, createRpcServices, createServerManager, createSystemTable, createTable, decommissionRegionServers, decorateMasterConfiguration, deleteColumn, deleteNamespace, deleteTable, disableReplicationPeer, disableTable, enableReplicationPeer, enableTable, executeRegionPlansWithThrottling, flushMasterStore, flushTable, getActiveMaster, getActiveMasterInfoPort, getActiveMasterManager, getAssignmentManager, getAverageLoad, getBackupMasterInfoPort, getBackupMasters, getBootstrapNodes, getCatalogJanitor, getClientIdAuditPrefix, getClusterId, getClusterMetrics, getClusterMetrics, getClusterMetricsWithoutCoprocessor, getClusterMetricsWithoutCoprocessor, getClusterSchema, getCompactionState, 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, getNamespace, getNamespaces, getNumWALFiles, getProcedures, getProcedureStore, getProcessName, getQuotaObserverChore, getRegionNormalizerManager, getRegionServerFatalLogBuffer, getRegionServerInfoPort, getRegionServerVersion, getRemoteInetAddress, getReplicationLoad, getReplicationLogCleanerBarrier, getReplicationPeerConfig, getReplicationPeerManager, getRSGroupInfoManager, getServerManager, getServerName, getSnapshotManager, getSnapshotQuotaObserverChore, getSpaceQuotaSnapshotNotifier, getSplitOrMergeStateStore, getSplitWALManager, getStartupProgress, getSyncReplicationPeerLock, getSyncReplicationReplayWALManager, getTableStateManager, getUseThisHostnameInstead, initClusterSchemaService, isActiveMaster, isBalancerOn, isCatalogJanitorEnabled, isCleanerChoreEnabled, isInitialized, isInMaintenanceMode, isNormalizerOn, isOnline, isReplicationPeerModificationEnabled, isSplitOrMergeEnabled, listDecommissionedRegionServers, listNamespaces, listReplicationPeers, listTableDescriptors, listTableDescriptorsByNamespace, listTableNames, listTableNamesByNamespace, login, main, mergeRegions, modifyColumn, modifyColumnStoreFileTracker, modifyNamespace, modifyTable, modifyTableStoreFileTracker, move, normalizeRegions, onConfigurationChange, recommissionRegionServer, registerService, remoteProcedureCompleted, remoteProcedureFailed, removeReplicationPeer, reopenRegions, replicationPeerModificationSwitch, reportMobCompactionEnd, reportMobCompactionStart, restoreSnapshot, runReplicationBarrierCleaner, setAssignmentManager, setCatalogJanitorEnabled, setDisableBalancerChoreForTest, setInitialized, setLoadBalancer, shutdown, skipRegionManagementAction, splitRegion, startProcedureExecutor, stop, stopChores, stopMaster, stopServiceThreads, switchSnapshotCleanup, transitReplicationPeerSyncReplicationState, truncateTable, updateConfigurationForQuotasObserver, updateReplicationPeerConfig, waitForMetaOnline
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
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, yield
equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getAccessChecker, getExecutorService, getTableDescriptors, getZKPermissionWatcher, isClusterUp
createConnection, getAsyncClusterConnection, getAsyncConnection, getChoreService, getConfiguration, getConnection, getCoordinatedStateManager, getFileSystem, getZooKeeper, isStopping
private MiniZooKeeperCluster zkcluster
public LocalHMaster(org.apache.hadoop.conf.Configuration conf) throws IOException
IOException
void setZKCluster(MiniZooKeeperCluster zkcluster)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.