Class VerifyingRSGroupAdmin

java.lang.Object
org.apache.hadoop.hbase.rsgroup.VerifyingRSGroupAdmin
All Implemented Interfaces:
Closeable, AutoCloseable, org.apache.hadoop.hbase.Abortable, org.apache.hadoop.hbase.client.Admin

@Private public class VerifyingRSGroupAdmin extends Object implements org.apache.hadoop.hbase.client.Admin, Closeable
  • Field Details

    • conn

      private final org.apache.hadoop.hbase.client.Connection conn
    • admin

      private final org.apache.hadoop.hbase.client.Admin admin
    • zkw

      private final org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw
  • Constructor Details

  • Method Details

    • getOperationTimeout

      public int getOperationTimeout()
      Specified by:
      getOperationTimeout in interface org.apache.hadoop.hbase.client.Admin
    • getSyncWaitTimeout

      public int getSyncWaitTimeout()
      Specified by:
      getSyncWaitTimeout in interface org.apache.hadoop.hbase.client.Admin
    • abort

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

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

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

      public boolean tableExists(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      tableExists in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableDescriptors

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors() throws IOException
      Specified by:
      listTableDescriptors in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableDescriptors

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors(boolean includeSysTables) throws IOException
      Specified by:
      listTableDescriptors in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableDescriptors

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors(Pattern pattern, boolean includeSysTables) throws IOException
      Specified by:
      listTableDescriptors in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableDescriptorsByState

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptorsByState(boolean isEnabled) throws IOException
      Specified by:
      listTableDescriptorsByState in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableNames

      public org.apache.hadoop.hbase.TableName[] listTableNames() throws IOException
      Specified by:
      listTableNames in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableNames

      public org.apache.hadoop.hbase.TableName[] listTableNames(Pattern pattern, boolean includeSysTables) throws IOException
      Specified by:
      listTableNames in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableNamesByState

      public List<org.apache.hadoop.hbase.TableName> listTableNamesByState(boolean isEnabled) throws IOException
      Specified by:
      listTableNamesByState in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getDescriptor

      public org.apache.hadoop.hbase.client.TableDescriptor getDescriptor(org.apache.hadoop.hbase.TableName tableName) throws org.apache.hadoop.hbase.TableNotFoundException, IOException
      Specified by:
      getDescriptor in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      org.apache.hadoop.hbase.TableNotFoundException
      IOException
    • createTable

      public void createTable(org.apache.hadoop.hbase.client.TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) throws IOException
      Specified by:
      createTable in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • createTableAsync

      public Future<Void> createTableAsync(org.apache.hadoop.hbase.client.TableDescriptor desc) throws IOException
      Specified by:
      createTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • createTableAsync

      public Future<Void> createTableAsync(org.apache.hadoop.hbase.client.TableDescriptor desc, byte[][] splitKeys) throws IOException
      Specified by:
      createTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteTableAsync

      public Future<Void> deleteTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      deleteTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • truncateTableAsync

      public Future<Void> truncateTableAsync(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) throws IOException
      Specified by:
      truncateTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • enableTableAsync

      public Future<Void> enableTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      enableTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • disableTableAsync

      public Future<Void> disableTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      disableTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isTableEnabled

      public boolean isTableEnabled(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      isTableEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isTableDisabled

      public boolean isTableDisabled(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      isTableDisabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isTableAvailable

      public boolean isTableAvailable(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      isTableAvailable in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • addColumnFamilyAsync

      public Future<Void> addColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) throws IOException
      Specified by:
      addColumnFamilyAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteColumnFamilyAsync

      public Future<Void> deleteColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) throws IOException
      Specified by:
      deleteColumnFamilyAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyColumnFamilyAsync

      public Future<Void> modifyColumnFamilyAsync(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) throws IOException
      Specified by:
      modifyColumnFamilyAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRegions

      public List<org.apache.hadoop.hbase.client.RegionInfo> getRegions(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flush

      public void flush(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      flush in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flush

      public void flush(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) throws IOException
      Specified by:
      flush in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flush

      public void flush(org.apache.hadoop.hbase.TableName tableName, List<byte[]> columnFamilies) throws IOException
      Specified by:
      flush in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flushRegion

      public void flushRegion(byte[] regionName) throws IOException
      Specified by:
      flushRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flushRegion

      public void flushRegion(byte[] regionName, byte[] columnFamily) throws IOException
      Specified by:
      flushRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flushRegionServer

      public void flushRegionServer(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      flushRegionServer in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compact

      public void compact(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      compact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compactRegion

      public void compactRegion(byte[] regionName) throws IOException
      Specified by:
      compactRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compact

      public void compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) throws IOException
      Specified by:
      compact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compactRegion

      public void compactRegion(byte[] regionName, byte[] columnFamily) throws IOException
      Specified by:
      compactRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compact

      public void compact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) throws IOException, InterruptedException
      Specified by:
      compact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      InterruptedException
    • compact

      public void compact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) throws IOException, InterruptedException
      Specified by:
      compact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      InterruptedException
    • majorCompact

      public void majorCompact(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      majorCompact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • majorCompactRegion

      public void majorCompactRegion(byte[] regionName) throws IOException
      Specified by:
      majorCompactRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • majorCompact

      public void majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) throws IOException
      Specified by:
      majorCompact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • majorCompactRegion

      public void majorCompactRegion(byte[] regionName, byte[] columnFamily) throws IOException
      Specified by:
      majorCompactRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • majorCompact

      public void majorCompact(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) throws IOException, InterruptedException
      Specified by:
      majorCompact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      InterruptedException
    • majorCompact

      public void majorCompact(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) throws IOException, InterruptedException
      Specified by:
      majorCompact in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      InterruptedException
    • compactionSwitch

      public Map<org.apache.hadoop.hbase.ServerName,Boolean> compactionSwitch(boolean switchState, List<String> serverNamesList) throws IOException
      Specified by:
      compactionSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • compactRegionServer

      public void compactRegionServer(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      compactRegionServer in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • majorCompactRegionServer

      public void majorCompactRegionServer(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      majorCompactRegionServer in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • move

      public void move(byte[] encodedRegionName) throws IOException
      Specified by:
      move in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • move

      public void move(byte[] encodedRegionName, org.apache.hadoop.hbase.ServerName destServerName) throws IOException
      Specified by:
      move in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • assign

      public void assign(byte[] regionName) throws IOException
      Specified by:
      assign in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • unassign

      public void unassign(byte[] regionName) throws IOException
      Specified by:
      unassign in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • offline

      public void offline(byte[] regionName) throws IOException
      Specified by:
      offline in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • balancerSwitch

      public boolean balancerSwitch(boolean onOrOff, boolean synchronous) throws IOException
      Specified by:
      balancerSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • balance

      public org.apache.hadoop.hbase.client.BalanceResponse balance(org.apache.hadoop.hbase.client.BalanceRequest request) throws IOException
      Specified by:
      balance in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isBalancerEnabled

      public boolean isBalancerEnabled() throws IOException
      Specified by:
      isBalancerEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • clearBlockCache

      public org.apache.hadoop.hbase.CacheEvictionStats clearBlockCache(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      clearBlockCache in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • normalize

      public boolean normalize(org.apache.hadoop.hbase.client.NormalizeTableFilterParams ntfp) throws IOException
      Specified by:
      normalize in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isNormalizerEnabled

      public boolean isNormalizerEnabled() throws IOException
      Specified by:
      isNormalizerEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • normalizerSwitch

      public boolean normalizerSwitch(boolean on) throws IOException
      Specified by:
      normalizerSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • catalogJanitorSwitch

      public boolean catalogJanitorSwitch(boolean onOrOff) throws IOException
      Specified by:
      catalogJanitorSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • runCatalogJanitor

      public int runCatalogJanitor() throws IOException
      Specified by:
      runCatalogJanitor in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isCatalogJanitorEnabled

      public boolean isCatalogJanitorEnabled() throws IOException
      Specified by:
      isCatalogJanitorEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • cleanerChoreSwitch

      public boolean cleanerChoreSwitch(boolean onOrOff) throws IOException
      Specified by:
      cleanerChoreSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • runCleanerChore

      public boolean runCleanerChore() throws IOException
      Specified by:
      runCleanerChore in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isCleanerChoreEnabled

      public boolean isCleanerChoreEnabled() throws IOException
      Specified by:
      isCleanerChoreEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • mergeRegionsAsync

      public Future<Void> mergeRegionsAsync(byte[][] nameofRegionsToMerge, boolean forcible) throws IOException
      Specified by:
      mergeRegionsAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • split

      public void split(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      split in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • split

      public void split(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint) throws IOException
      Specified by:
      split in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • splitRegionAsync

      public Future<Void> splitRegionAsync(byte[] regionName) throws IOException
      Specified by:
      splitRegionAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • splitRegionAsync

      public Future<Void> splitRegionAsync(byte[] regionName, byte[] splitPoint) throws IOException
      Specified by:
      splitRegionAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • truncateRegion

      public void truncateRegion(byte[] regionName) throws IOException
      Specified by:
      truncateRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • truncateRegionAsync

      public Future<Void> truncateRegionAsync(byte[] regionName) throws IOException
      Specified by:
      truncateRegionAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyTableAsync

      public Future<Void> modifyTableAsync(org.apache.hadoop.hbase.client.TableDescriptor td) throws IOException
      Specified by:
      modifyTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyTableAsync

      public Future<Void> modifyTableAsync(org.apache.hadoop.hbase.client.TableDescriptor td, boolean reopenRegions) throws IOException
      Specified by:
      modifyTableAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • shutdown

      public void shutdown() throws IOException
      Specified by:
      shutdown in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • stopMaster

      public void stopMaster() throws IOException
      Specified by:
      stopMaster in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isMasterInMaintenanceMode

      public boolean isMasterInMaintenanceMode() throws IOException
      Specified by:
      isMasterInMaintenanceMode in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • stopRegionServer

      public void stopRegionServer(String hostnamePort) throws IOException
      Specified by:
      stopRegionServer in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getClusterMetrics

      public org.apache.hadoop.hbase.ClusterMetrics getClusterMetrics(EnumSet<org.apache.hadoop.hbase.ClusterMetrics.Option> options) throws IOException
      Specified by:
      getClusterMetrics in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRegionMetrics

      public List<org.apache.hadoop.hbase.RegionMetrics> getRegionMetrics(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      getRegionMetrics in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRegionMetrics

      public List<org.apache.hadoop.hbase.RegionMetrics> getRegionMetrics(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getRegionMetrics in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getConfiguration

      public org.apache.hadoop.conf.Configuration getConfiguration()
      Specified by:
      getConfiguration in interface org.apache.hadoop.hbase.client.Admin
    • createNamespaceAsync

      public Future<Void> createNamespaceAsync(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) throws IOException
      Specified by:
      createNamespaceAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyNamespaceAsync

      public Future<Void> modifyNamespaceAsync(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) throws IOException
      Specified by:
      modifyNamespaceAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteNamespaceAsync

      Specified by:
      deleteNamespaceAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getNamespaceDescriptor

      public org.apache.hadoop.hbase.NamespaceDescriptor getNamespaceDescriptor(String name) throws org.apache.hadoop.hbase.NamespaceNotFoundException, IOException
      Specified by:
      getNamespaceDescriptor in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      org.apache.hadoop.hbase.NamespaceNotFoundException
      IOException
    • listNamespaces

      public String[] listNamespaces() throws IOException
      Specified by:
      listNamespaces in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listNamespaceDescriptors

      public org.apache.hadoop.hbase.NamespaceDescriptor[] listNamespaceDescriptors() throws IOException
      Specified by:
      listNamespaceDescriptors in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableDescriptorsByNamespace

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptorsByNamespace(byte[] name) throws IOException
      Specified by:
      listTableDescriptorsByNamespace in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableNamesByNamespace

      public org.apache.hadoop.hbase.TableName[] listTableNamesByNamespace(String name) throws IOException
      Specified by:
      listTableNamesByNamespace in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRegions

      public List<org.apache.hadoop.hbase.client.RegionInfo> getRegions(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • close

      public void close()
      Specified by:
      close in interface org.apache.hadoop.hbase.client.Admin
      Specified by:
      close in interface AutoCloseable
      Specified by:
      close in interface Closeable
    • listTableDescriptors

      public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNames) throws IOException
      Specified by:
      listTableDescriptors in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • abortProcedureAsync

      public Future<Boolean> abortProcedureAsync(long procId, boolean mayInterruptIfRunning) throws IOException
      Specified by:
      abortProcedureAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getProcedures

      public String getProcedures() throws IOException
      Specified by:
      getProcedures in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getLocks

      public String getLocks() throws IOException
      Specified by:
      getLocks in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • rollWALWriter

      public void rollWALWriter(org.apache.hadoop.hbase.ServerName serverName) throws IOException, org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
      Specified by:
      rollWALWriter in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
    • getCompactionState

      public org.apache.hadoop.hbase.client.CompactionState getCompactionState(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getCompactionState in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getCompactionState

      public org.apache.hadoop.hbase.client.CompactionState getCompactionState(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) throws IOException
      Specified by:
      getCompactionState in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getCompactionStateForRegion

      public org.apache.hadoop.hbase.client.CompactionState getCompactionStateForRegion(byte[] regionName) throws IOException
      Specified by:
      getCompactionStateForRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getLastMajorCompactionTimestamp

      public long getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getLastMajorCompactionTimestamp in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getLastMajorCompactionTimestampForRegion

      public long getLastMajorCompactionTimestampForRegion(byte[] regionName) throws IOException
      Specified by:
      getLastMajorCompactionTimestampForRegion in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • snapshot

      public void snapshot(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) throws IOException, org.apache.hadoop.hbase.snapshot.SnapshotCreationException, IllegalArgumentException
      Specified by:
      snapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.snapshot.SnapshotCreationException
      IllegalArgumentException
    • snapshotAsync

      public Future<Void> snapshotAsync(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) throws IOException, org.apache.hadoop.hbase.snapshot.SnapshotCreationException
      Specified by:
      snapshotAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.snapshot.SnapshotCreationException
    • isSnapshotFinished

      public boolean isSnapshotFinished(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) throws IOException, org.apache.hadoop.hbase.snapshot.HBaseSnapshotException, org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
      Specified by:
      isSnapshotFinished in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
      org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
    • restoreSnapshot

      public void restoreSnapshot(String snapshotName) throws IOException, org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
      Specified by:
      restoreSnapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
    • restoreSnapshot

      public void restoreSnapshot(String snapshotName, boolean takeFailSafeSnapshot, boolean restoreAcl) throws IOException, org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
      Specified by:
      restoreSnapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
    • cloneSnapshotAsync

      public Future<Void> cloneSnapshotAsync(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT) throws IOException, org.apache.hadoop.hbase.TableExistsException, org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
      Specified by:
      cloneSnapshotAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      org.apache.hadoop.hbase.TableExistsException
      org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
    • execProcedure

      public void execProcedure(String signature, String instance, Map<String,String> props) throws IOException
      Specified by:
      execProcedure in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • execProcedureWithReturn

      public byte[] execProcedureWithReturn(String signature, String instance, Map<String,String> props) throws IOException
      Specified by:
      execProcedureWithReturn in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isProcedureFinished

      public boolean isProcedureFinished(String signature, String instance, Map<String,String> props) throws IOException
      Specified by:
      isProcedureFinished in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listSnapshots

      public List<org.apache.hadoop.hbase.client.SnapshotDescription> listSnapshots() throws IOException
      Specified by:
      listSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listSnapshots

      public List<org.apache.hadoop.hbase.client.SnapshotDescription> listSnapshots(Pattern pattern) throws IOException
      Specified by:
      listSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTableSnapshots

      public List<org.apache.hadoop.hbase.client.SnapshotDescription> listTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) throws IOException
      Specified by:
      listTableSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteSnapshot

      public void deleteSnapshot(String snapshotName) throws IOException
      Specified by:
      deleteSnapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteSnapshots

      public void deleteSnapshots(Pattern pattern) throws IOException
      Specified by:
      deleteSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • deleteTableSnapshots

      public void deleteTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) throws IOException
      Specified by:
      deleteTableSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • setQuota

      public void setQuota(org.apache.hadoop.hbase.quotas.QuotaSettings quota) throws IOException
      Specified by:
      setQuota in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getQuota

      public List<org.apache.hadoop.hbase.quotas.QuotaSettings> getQuota(org.apache.hadoop.hbase.quotas.QuotaFilter filter) throws IOException
      Specified by:
      getQuota in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • coprocessorService

      public org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService()
      Specified by:
      coprocessorService in interface org.apache.hadoop.hbase.client.Admin
    • coprocessorService

      public org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService(org.apache.hadoop.hbase.ServerName serverName)
      Specified by:
      coprocessorService in interface org.apache.hadoop.hbase.client.Admin
    • updateConfiguration

      public void updateConfiguration(org.apache.hadoop.hbase.ServerName server) throws IOException
      Specified by:
      updateConfiguration in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • updateConfiguration

      public void updateConfiguration() throws IOException
      Specified by:
      updateConfiguration in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • updateConfiguration

      public void updateConfiguration(String groupName) throws IOException
      Specified by:
      updateConfiguration in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getSecurityCapabilities

      public List<org.apache.hadoop.hbase.client.security.SecurityCapability> getSecurityCapabilities() throws IOException
      Specified by:
      getSecurityCapabilities in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • splitSwitch

      public boolean splitSwitch(boolean enabled, boolean synchronous) throws IOException
      Specified by:
      splitSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • mergeSwitch

      public boolean mergeSwitch(boolean enabled, boolean synchronous) throws IOException
      Specified by:
      mergeSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isSplitEnabled

      public boolean isSplitEnabled() throws IOException
      Specified by:
      isSplitEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isMergeEnabled

      public boolean isMergeEnabled() throws IOException
      Specified by:
      isMergeEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • addReplicationPeerAsync

      public Future<Void> addReplicationPeerAsync(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) throws IOException
      Specified by:
      addReplicationPeerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • removeReplicationPeerAsync

      Specified by:
      removeReplicationPeerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • enableReplicationPeerAsync

      Specified by:
      enableReplicationPeerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • disableReplicationPeerAsync

      Specified by:
      disableReplicationPeerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getReplicationPeerConfig

      public org.apache.hadoop.hbase.replication.ReplicationPeerConfig getReplicationPeerConfig(String peerId) throws IOException
      Specified by:
      getReplicationPeerConfig in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • updateReplicationPeerConfigAsync

      public Future<Void> updateReplicationPeerConfigAsync(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) throws IOException
      Specified by:
      updateReplicationPeerConfigAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listReplicationPeers

      public List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription> listReplicationPeers() throws IOException
      Specified by:
      listReplicationPeers in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listReplicationPeers

      public List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription> listReplicationPeers(Pattern pattern) throws IOException
      Specified by:
      listReplicationPeers in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • transitReplicationPeerSyncReplicationStateAsync

      public Future<Void> transitReplicationPeerSyncReplicationStateAsync(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) throws IOException
      Specified by:
      transitReplicationPeerSyncReplicationStateAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isReplicationPeerEnabled

      public boolean isReplicationPeerEnabled(String peerId) throws IOException
      Specified by:
      isReplicationPeerEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • decommissionRegionServers

      public void decommissionRegionServers(List<org.apache.hadoop.hbase.ServerName> servers, boolean offload) throws IOException
      Specified by:
      decommissionRegionServers in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listDecommissionedRegionServers

      public List<org.apache.hadoop.hbase.ServerName> listDecommissionedRegionServers() throws IOException
      Specified by:
      listDecommissionedRegionServers in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • recommissionRegionServer

      public void recommissionRegionServer(org.apache.hadoop.hbase.ServerName server, List<byte[]> encodedRegionNames) throws IOException
      Specified by:
      recommissionRegionServer in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listReplicatedTableCFs

      public List<org.apache.hadoop.hbase.client.replication.TableCFs> listReplicatedTableCFs() throws IOException
      Specified by:
      listReplicatedTableCFs in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • enableTableReplication

      public void enableTableReplication(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      enableTableReplication in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • disableTableReplication

      public void disableTableReplication(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      disableTableReplication in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • clearCompactionQueues

      public void clearCompactionQueues(org.apache.hadoop.hbase.ServerName serverName, Set<String> queues) throws IOException, InterruptedException
      Specified by:
      clearCompactionQueues in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
      InterruptedException
    • clearDeadServers

      public List<org.apache.hadoop.hbase.ServerName> clearDeadServers(List<org.apache.hadoop.hbase.ServerName> servers) throws IOException
      Specified by:
      clearDeadServers in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • cloneTableSchema

      public void cloneTableSchema(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits) throws IOException
      Specified by:
      cloneTableSchema in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • switchRpcThrottle

      public boolean switchRpcThrottle(boolean enable) throws IOException
      Specified by:
      switchRpcThrottle in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isRpcThrottleEnabled

      public boolean isRpcThrottleEnabled() throws IOException
      Specified by:
      isRpcThrottleEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • exceedThrottleQuotaSwitch

      public boolean exceedThrottleQuotaSwitch(boolean enable) throws IOException
      Specified by:
      exceedThrottleQuotaSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getSpaceQuotaTableSizes

      public Map<org.apache.hadoop.hbase.TableName,Long> getSpaceQuotaTableSizes() throws IOException
      Specified by:
      getSpaceQuotaTableSizes in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRegionServerSpaceQuotaSnapshots

      public Map<org.apache.hadoop.hbase.TableName,? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView> getRegionServerSpaceQuotaSnapshots(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      getRegionServerSpaceQuotaSnapshots in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getCurrentSpaceQuotaSnapshot

      public org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView getCurrentSpaceQuotaSnapshot(String namespace) throws IOException
      Specified by:
      getCurrentSpaceQuotaSnapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getCurrentSpaceQuotaSnapshot

      public org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView getCurrentSpaceQuotaSnapshot(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getCurrentSpaceQuotaSnapshot in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • grant

      public void grant(org.apache.hadoop.hbase.security.access.UserPermission userPermission, boolean mergeExistingPermissions) throws IOException
      Specified by:
      grant in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • revoke

      public void revoke(org.apache.hadoop.hbase.security.access.UserPermission userPermission) throws IOException
      Specified by:
      revoke in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getUserPermissions

      public List<org.apache.hadoop.hbase.security.access.UserPermission> getUserPermissions(org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest getUserPermissionsRequest) throws IOException
      Specified by:
      getUserPermissions in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • hasUserPermissions

      public List<Boolean> hasUserPermissions(String userName, List<org.apache.hadoop.hbase.security.access.Permission> permissions) throws IOException
      Specified by:
      hasUserPermissions in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • snapshotCleanupSwitch

      public boolean snapshotCleanupSwitch(boolean on, boolean synchronous) throws IOException
      Specified by:
      snapshotCleanupSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isSnapshotCleanupEnabled

      public boolean isSnapshotCleanupEnabled() throws IOException
      Specified by:
      isSnapshotCleanupEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • addRSGroup

      public void addRSGroup(String groupName) throws IOException
      Specified by:
      addRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRSGroup

      public org.apache.hadoop.hbase.rsgroup.RSGroupInfo getRSGroup(String groupName) throws IOException
      Specified by:
      getRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRSGroup

      public org.apache.hadoop.hbase.rsgroup.RSGroupInfo getRSGroup(org.apache.hadoop.hbase.net.Address hostPort) throws IOException
      Specified by:
      getRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getRSGroup

      public org.apache.hadoop.hbase.rsgroup.RSGroupInfo getRSGroup(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listRSGroups

      public List<org.apache.hadoop.hbase.rsgroup.RSGroupInfo> listRSGroups() throws IOException
      Specified by:
      listRSGroups in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • listTablesInRSGroup

      public List<org.apache.hadoop.hbase.TableName> listTablesInRSGroup(String groupName) throws IOException
      Specified by:
      listTablesInRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getConfiguredNamespacesAndTablesInRSGroup

      public org.apache.hadoop.hbase.util.Pair<List<String>,List<org.apache.hadoop.hbase.TableName>> getConfiguredNamespacesAndTablesInRSGroup(String groupName) throws IOException
      Specified by:
      getConfiguredNamespacesAndTablesInRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • removeRSGroup

      public void removeRSGroup(String groupName) throws IOException
      Specified by:
      removeRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • removeServersFromRSGroup

      public void removeServersFromRSGroup(Set<org.apache.hadoop.hbase.net.Address> servers) throws IOException
      Specified by:
      removeServersFromRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • moveServersToRSGroup

      public void moveServersToRSGroup(Set<org.apache.hadoop.hbase.net.Address> servers, String targetGroup) throws IOException
      Specified by:
      moveServersToRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • setRSGroup

      public void setRSGroup(Set<org.apache.hadoop.hbase.TableName> tables, String groupName) throws IOException
      Specified by:
      setRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • balanceRSGroup

      public org.apache.hadoop.hbase.client.BalanceResponse balanceRSGroup(String groupName, org.apache.hadoop.hbase.client.BalanceRequest request) throws IOException
      Specified by:
      balanceRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • renameRSGroup

      public void renameRSGroup(String oldName, String newName) throws IOException
      Specified by:
      renameRSGroup in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • updateRSGroupConfig

      public void updateRSGroupConfig(String groupName, Map<String,String> configuration) throws IOException
      Specified by:
      updateRSGroupConfig in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getLogEntries

      public List<org.apache.hadoop.hbase.client.LogEntry> getLogEntries(Set<org.apache.hadoop.hbase.ServerName> serverNames, String logType, org.apache.hadoop.hbase.client.ServerType serverType, int limit, Map<String,Object> filterParams) throws IOException
      Specified by:
      getLogEntries in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • verify

      private void verify() throws IOException
      Throws:
      IOException
    • clearSlowLogResponses

      public List<Boolean> clearSlowLogResponses(Set<org.apache.hadoop.hbase.ServerName> serverNames) throws IOException
      Specified by:
      clearSlowLogResponses in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyColumnFamilyStoreFileTrackerAsync

      public Future<Void> modifyColumnFamilyStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) throws IOException
      Specified by:
      modifyColumnFamilyStoreFileTrackerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • modifyTableStoreFileTrackerAsync

      public Future<Void> modifyTableStoreFileTrackerAsync(org.apache.hadoop.hbase.TableName tableName, String dstSFT) throws IOException
      Specified by:
      modifyTableStoreFileTrackerAsync in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • flushMasterStore

      public void flushMasterStore() throws IOException
      Specified by:
      flushMasterStore in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • getCachedFilesList

      public List<String> getCachedFilesList(org.apache.hadoop.hbase.ServerName serverName) throws IOException
      Specified by:
      getCachedFilesList in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • replicationPeerModificationSwitch

      public boolean replicationPeerModificationSwitch(boolean on, boolean drainProcedures) throws IOException
      Specified by:
      replicationPeerModificationSwitch in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException
    • isReplicationPeerModificationEnabled

      Specified by:
      isReplicationPeerModificationEnabled in interface org.apache.hadoop.hbase.client.Admin
      Throws:
      IOException