Class MockNoopMasterServices

java.lang.Object
org.apache.hadoop.hbase.master.MockNoopMasterServices
All Implemented Interfaces:
org.apache.hadoop.hbase.Abortable, org.apache.hadoop.hbase.master.MasterServices, org.apache.hadoop.hbase.Server, org.apache.hadoop.hbase.Stoppable
Direct Known Subclasses:
MockMasterServices, TestClockSkewDetection.DummyMasterServices, TestSplitLogManager.DummyMasterServices

public class MockNoopMasterServices extends Object implements org.apache.hadoop.hbase.master.MasterServices
  • Field Details

    • conf

      private final org.apache.hadoop.conf.Configuration conf
    • metricsMaster

      private final org.apache.hadoop.hbase.master.MetricsMaster metricsMaster
    • stopped

      private boolean stopped
  • Constructor Details

  • Method Details

    • checkTableModifiable

      public void checkTableModifiable(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      checkTableModifiable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • truncateRegion

      public long truncateRegion(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long nonceGroup, long nonce) throws IOException
      Specified by:
      truncateRegion in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • createTable

      public long createTable(org.apache.hadoop.hbase.client.TableDescriptor desc, byte[][] splitKeys, long nonceGroup, long nonce) throws IOException
      Specified by:
      createTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • createSystemTable

      public long createSystemTable(org.apache.hadoop.hbase.client.TableDescriptor tableDescriptor) throws IOException
      Specified by:
      createSystemTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getAssignmentManager

      public org.apache.hadoop.hbase.master.assignment.AssignmentManager getAssignmentManager()
      Specified by:
      getAssignmentManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getExecutorService

      public org.apache.hadoop.hbase.executor.ExecutorService getExecutorService()
      Specified by:
      getExecutorService in interface org.apache.hadoop.hbase.master.MasterServices
    • getChoreService

      public org.apache.hadoop.hbase.ChoreService getChoreService()
      Specified by:
      getChoreService in interface org.apache.hadoop.hbase.Server
    • getCatalogJanitor

      public org.apache.hadoop.hbase.master.janitor.CatalogJanitor getCatalogJanitor()
      Specified by:
      getCatalogJanitor in interface org.apache.hadoop.hbase.master.MasterServices
    • getHbckChore

      public org.apache.hadoop.hbase.master.hbck.HbckChore getHbckChore()
      Specified by:
      getHbckChore in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterFileSystem

      public org.apache.hadoop.hbase.master.MasterFileSystem getMasterFileSystem()
      Specified by:
      getMasterFileSystem in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterWalManager

      public org.apache.hadoop.hbase.master.MasterWalManager getMasterWalManager()
      Specified by:
      getMasterWalManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterCoprocessorHost

      public org.apache.hadoop.hbase.master.MasterCoprocessorHost getMasterCoprocessorHost()
      Specified by:
      getMasterCoprocessorHost in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterQuotaManager

      public org.apache.hadoop.hbase.quotas.MasterQuotaManager getMasterQuotaManager()
      Specified by:
      getMasterQuotaManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getRegionNormalizerManager

      public org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager getRegionNormalizerManager()
      Specified by:
      getRegionNormalizerManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterProcedureExecutor

      public org.apache.hadoop.hbase.procedure2.ProcedureExecutor<org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv> getMasterProcedureExecutor()
      Specified by:
      getMasterProcedureExecutor in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterMetrics

      public org.apache.hadoop.hbase.master.MetricsMaster getMasterMetrics()
      Specified by:
      getMasterMetrics in interface org.apache.hadoop.hbase.master.MasterServices
    • getServerManager

      public org.apache.hadoop.hbase.master.ServerManager getServerManager()
      Specified by:
      getServerManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getZooKeeper

      public org.apache.hadoop.hbase.zookeeper.ZKWatcher getZooKeeper()
      Specified by:
      getZooKeeper in interface org.apache.hadoop.hbase.Server
    • getCoordinatedStateManager

      public org.apache.hadoop.hbase.CoordinatedStateManager getCoordinatedStateManager()
      Specified by:
      getCoordinatedStateManager in interface org.apache.hadoop.hbase.Server
    • getConnection

      public org.apache.hadoop.hbase.client.Connection getConnection()
      Specified by:
      getConnection in interface org.apache.hadoop.hbase.Server
    • getConfiguration

      public org.apache.hadoop.conf.Configuration getConfiguration()
      Specified by:
      getConfiguration in interface org.apache.hadoop.hbase.Server
    • getServerName

      public org.apache.hadoop.hbase.ServerName getServerName()
      Specified by:
      getServerName in interface org.apache.hadoop.hbase.Server
    • abort

      public void abort(String why, Throwable e)
      Specified by:
      abort in interface org.apache.hadoop.hbase.Abortable
    • isAborted

      public boolean isAborted()
      Specified by:
      isAborted in interface org.apache.hadoop.hbase.Abortable
    • stop

      public void stop(String why)
      Specified by:
      stop in interface org.apache.hadoop.hbase.Stoppable
    • isStopping

      public boolean isStopping()
      Specified by:
      isStopping in interface org.apache.hadoop.hbase.Server
    • isStopped

      public boolean isStopped()
      Specified by:
      isStopped in interface org.apache.hadoop.hbase.Stoppable
    • getTableDescriptors

      public org.apache.hadoop.hbase.TableDescriptors getTableDescriptors()
      Specified by:
      getTableDescriptors in interface org.apache.hadoop.hbase.master.MasterServices
    • registerService

      public boolean registerService(org.apache.hbase.thirdparty.com.google.protobuf.Service instance)
      Specified by:
      registerService in interface org.apache.hadoop.hbase.master.MasterServices
    • abortProcedure

      public boolean abortProcedure(long procId, boolean mayInterruptIfRunning) throws IOException
      Specified by:
      abortProcedure in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getProcedures

      public List<org.apache.hadoop.hbase.procedure2.Procedure<?>> getProcedures() throws IOException
      Specified by:
      getProcedures in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getLocks

      public List<org.apache.hadoop.hbase.procedure2.LockedResource> getLocks() throws IOException
      Specified by:
      getLocks in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • listTableDescriptorsByNamespace

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptorsByNamespace(String name) throws IOException
      Specified by:
      listTableDescriptorsByNamespace in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • listTableNamesByNamespace

      public List<org.apache.hadoop.hbase.TableName> listTableNamesByNamespace(String name) throws IOException
      Specified by:
      listTableNamesByNamespace in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • deleteTable

      public long deleteTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) throws IOException
      Specified by:
      deleteTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • truncateTable

      public long truncateTable(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits, long nonceGroup, long nonce) throws IOException
      Specified by:
      truncateTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • modifyTable

      public long modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce) throws IOException
      Specified by:
      modifyTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • modifyTable

      public long modifyTable(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor descriptor, long nonceGroup, long nonce, boolean reopenRegions) throws IOException
      Specified by:
      modifyTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • enableTable

      public long enableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) throws IOException
      Specified by:
      enableTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • disableTable

      public long disableTable(org.apache.hadoop.hbase.TableName tableName, long nonceGroup, long nonce) throws IOException
      Specified by:
      disableTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • addColumn

      public long addColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnDescriptor, long nonceGroup, long nonce) throws IOException
      Specified by:
      addColumn in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • modifyColumn

      public long modifyColumn(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor descriptor, long nonceGroup, long nonce) throws IOException
      Specified by:
      modifyColumn in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • deleteColumn

      public long deleteColumn(org.apache.hadoop.hbase.TableName tableName, byte[] columnName, long nonceGroup, long nonce) throws IOException
      Specified by:
      deleteColumn in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • mergeRegions

      public long mergeRegions(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, boolean forcible, long nonceGroup, long nonce) throws IOException
      Specified by:
      mergeRegions in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • splitRegion

      public long splitRegion(org.apache.hadoop.hbase.client.RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) throws IOException
      Specified by:
      splitRegion in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getTableStateManager

      public org.apache.hadoop.hbase.master.TableStateManager getTableStateManager()
      Specified by:
      getTableStateManager in interface org.apache.hadoop.hbase.master.MasterServices
    • isActiveMaster

      public boolean isActiveMaster()
      Specified by:
      isActiveMaster in interface org.apache.hadoop.hbase.master.MasterServices
    • isInitialized

      public boolean isInitialized()
      Specified by:
      isInitialized in interface org.apache.hadoop.hbase.master.MasterServices
    • isInMaintenanceMode

      public boolean isInMaintenanceMode()
      Specified by:
      isInMaintenanceMode in interface org.apache.hadoop.hbase.master.MasterServices
    • skipRegionManagementAction

      public boolean skipRegionManagementAction(String action)
      Specified by:
      skipRegionManagementAction in interface org.apache.hadoop.hbase.master.MasterServices
    • getLastMajorCompactionTimestamp

      public long getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName table) throws IOException
      Specified by:
      getLastMajorCompactionTimestamp in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getLastMajorCompactionTimestampForRegion

      public long getLastMajorCompactionTimestampForRegion(byte[] regionName) throws IOException
      Specified by:
      getLastMajorCompactionTimestampForRegion in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • getClusterSchema

      public org.apache.hadoop.hbase.master.ClusterSchema getClusterSchema()
      Specified by:
      getClusterSchema in interface org.apache.hadoop.hbase.master.MasterServices
    • getLoadBalancer

      public org.apache.hadoop.hbase.master.LoadBalancer getLoadBalancer()
      Specified by:
      getLoadBalancer in interface org.apache.hadoop.hbase.master.MasterServices
    • getFavoredNodesManager

      public org.apache.hadoop.hbase.favored.FavoredNodesManager getFavoredNodesManager()
      Specified by:
      getFavoredNodesManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getSnapshotManager

      public org.apache.hadoop.hbase.master.snapshot.SnapshotManager getSnapshotManager()
      Specified by:
      getSnapshotManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getMasterProcedureManagerHost

      public org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost getMasterProcedureManagerHost()
      Specified by:
      getMasterProcedureManagerHost in interface org.apache.hadoop.hbase.master.MasterServices
    • isSplitOrMergeEnabled

      public boolean isSplitOrMergeEnabled(org.apache.hadoop.hbase.client.MasterSwitchType switchType)
      Specified by:
      isSplitOrMergeEnabled in interface org.apache.hadoop.hbase.master.MasterServices
    • addReplicationPeer

      public long addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) throws org.apache.hadoop.hbase.replication.ReplicationException
      Specified by:
      addReplicationPeer in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
    • removeReplicationPeer

      public long removeReplicationPeer(String peerId) throws org.apache.hadoop.hbase.replication.ReplicationException
      Specified by:
      removeReplicationPeer in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
    • enableReplicationPeer

      public long enableReplicationPeer(String peerId) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      enableReplicationPeer in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • disableReplicationPeer

      public long disableReplicationPeer(String peerId) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      disableReplicationPeer in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • getReplicationPeerConfig

      public org.apache.hadoop.hbase.replication.ReplicationPeerConfig getReplicationPeerConfig(String peerId) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      getReplicationPeerConfig in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • updateReplicationPeerConfig

      public long updateReplicationPeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      updateReplicationPeerConfig in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • listReplicationPeers

      public List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription> listReplicationPeers(String regex) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      listReplicationPeers in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • getLockManager

      public org.apache.hadoop.hbase.master.locking.LockManager getLockManager()
      Specified by:
      getLockManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getRegionServerVersion

      public String getRegionServerVersion(org.apache.hadoop.hbase.ServerName sn)
      Specified by:
      getRegionServerVersion in interface org.apache.hadoop.hbase.master.MasterServices
    • checkIfShouldMoveSystemRegionAsync

      Specified by:
      checkIfShouldMoveSystemRegionAsync in interface org.apache.hadoop.hbase.master.MasterServices
    • getClientIdAuditPrefix

      Specified by:
      getClientIdAuditPrefix in interface org.apache.hadoop.hbase.master.MasterServices
    • getInitializedEvent

      public org.apache.hadoop.hbase.procedure2.ProcedureEvent<?> getInitializedEvent()
      Specified by:
      getInitializedEvent in interface org.apache.hadoop.hbase.master.MasterServices
    • getFileSystem

      public org.apache.hadoop.fs.FileSystem getFileSystem()
      Specified by:
      getFileSystem in interface org.apache.hadoop.hbase.Server
    • createConnection

      public org.apache.hadoop.hbase.client.Connection createConnection(org.apache.hadoop.conf.Configuration conf) throws IOException
      Specified by:
      createConnection in interface org.apache.hadoop.hbase.Server
      Throws:
      IOException
    • getReplicationPeerManager

      public org.apache.hadoop.hbase.master.replication.ReplicationPeerManager getReplicationPeerManager()
      Specified by:
      getReplicationPeerManager in interface org.apache.hadoop.hbase.master.MasterServices
    • isClusterUp

      public boolean isClusterUp()
      Specified by:
      isClusterUp in interface org.apache.hadoop.hbase.master.MasterServices
    • transitReplicationPeerSyncReplicationState

      public long transitReplicationPeerSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState clusterState) throws org.apache.hadoop.hbase.replication.ReplicationException, IOException
      Specified by:
      transitReplicationPeerSyncReplicationState in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      org.apache.hadoop.hbase.replication.ReplicationException
      IOException
    • getSyncReplicationReplayWALManager

      public org.apache.hadoop.hbase.master.replication.SyncReplicationReplayWALManager getSyncReplicationReplayWALManager()
      Specified by:
      getSyncReplicationReplayWALManager in interface org.apache.hadoop.hbase.master.MasterServices
    • getAccessChecker

      public org.apache.hadoop.hbase.security.access.AccessChecker getAccessChecker()
      Specified by:
      getAccessChecker in interface org.apache.hadoop.hbase.master.MasterServices
    • getZKPermissionWatcher

      public org.apache.hadoop.hbase.security.access.ZKPermissionWatcher getZKPermissionWatcher()
      Specified by:
      getZKPermissionWatcher in interface org.apache.hadoop.hbase.master.MasterServices
    • executeRegionPlansWithThrottling

      public List<org.apache.hadoop.hbase.master.RegionPlan> executeRegionPlansWithThrottling(List<org.apache.hadoop.hbase.master.RegionPlan> plans)
      Specified by:
      executeRegionPlansWithThrottling in interface org.apache.hadoop.hbase.master.MasterServices
    • getAsyncClusterConnection

      public org.apache.hadoop.hbase.client.AsyncClusterConnection getAsyncClusterConnection()
      Specified by:
      getAsyncClusterConnection in interface org.apache.hadoop.hbase.Server
    • runReplicationBarrierCleaner

      Specified by:
      runReplicationBarrierCleaner in interface org.apache.hadoop.hbase.master.MasterServices
    • getRSGroupInfoManager

      public org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager getRSGroupInfoManager()
      Specified by:
      getRSGroupInfoManager in interface org.apache.hadoop.hbase.master.MasterServices
    • isBalancerOn

      public boolean isBalancerOn()
      Specified by:
      isBalancerOn in interface org.apache.hadoop.hbase.master.MasterServices
    • normalizeRegions

      public boolean normalizeRegions(org.apache.hadoop.hbase.client.NormalizeTableFilterParams ntfp, boolean isHighPriority)
      Specified by:
      normalizeRegions in interface org.apache.hadoop.hbase.master.MasterServices
    • getMetaLocationSyncer

      public org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer getMetaLocationSyncer()
      Specified by:
      getMetaLocationSyncer in interface org.apache.hadoop.hbase.master.MasterServices
    • flushMasterStore

      public void flushMasterStore()
      Specified by:
      flushMasterStore in interface org.apache.hadoop.hbase.master.MasterServices
    • modifyTableStoreFileTracker

      public long modifyTableStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, String dstSFT, long nonceGroup, long nonce) throws IOException
      Specified by:
      modifyTableStoreFileTracker in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • modifyColumnStoreFileTracker

      public long modifyColumnStoreFileTracker(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT, long nonceGroup, long nonce) throws IOException
      Specified by:
      modifyColumnStoreFileTracker in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • replicationPeerModificationSwitch

      public boolean replicationPeerModificationSwitch(boolean on) throws IOException
      Specified by:
      replicationPeerModificationSwitch in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException
    • isReplicationPeerModificationEnabled

      Specified by:
      isReplicationPeerModificationEnabled in interface org.apache.hadoop.hbase.master.MasterServices
    • getReplicationLogCleanerBarrier

      public org.apache.hadoop.hbase.replication.master.ReplicationLogCleanerBarrier getReplicationLogCleanerBarrier()
      Specified by:
      getReplicationLogCleanerBarrier in interface org.apache.hadoop.hbase.master.MasterServices
    • getSyncReplicationPeerLock

      Specified by:
      getSyncReplicationPeerLock in interface org.apache.hadoop.hbase.master.MasterServices
    • flushTable

      public long flushTable(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies, long nonceGroup, long nonce) throws IOException
      Specified by:
      flushTable in interface org.apache.hadoop.hbase.master.MasterServices
      Throws:
      IOException