Package org.apache.hadoop.hbase.rsgroup
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 Summary
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionvoid
abortProcedureAsync
(long procId, boolean mayInterruptIfRunning) addColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) addReplicationPeerAsync
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) void
addRSGroup
(String groupName) void
assign
(byte[] regionName) org.apache.hadoop.hbase.client.BalanceResponse
balance
(org.apache.hadoop.hbase.client.BalanceRequest request) org.apache.hadoop.hbase.client.BalanceResponse
balanceRSGroup
(String groupName, org.apache.hadoop.hbase.client.BalanceRequest request) boolean
balancerSwitch
(boolean onOrOff, boolean synchronous) boolean
catalogJanitorSwitch
(boolean onOrOff) boolean
cleanerChoreSwitch
(boolean onOrOff) org.apache.hadoop.hbase.CacheEvictionStats
clearBlockCache
(org.apache.hadoop.hbase.TableName tableName) void
clearCompactionQueues
(org.apache.hadoop.hbase.ServerName serverName, Set<String> queues) List<org.apache.hadoop.hbase.ServerName>
clearDeadServers
(List<org.apache.hadoop.hbase.ServerName> servers) clearSlowLogResponses
(Set<org.apache.hadoop.hbase.ServerName> serverNames) cloneSnapshotAsync
(String snapshotName, org.apache.hadoop.hbase.TableName tableName, boolean restoreAcl, String customSFT) void
cloneTableSchema
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.TableName newTableName, boolean preserveSplits) void
close()
void
compact
(org.apache.hadoop.hbase.TableName tableName) void
compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) void
compact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) void
compact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) compactionSwitch
(boolean switchState, List<String> serverNamesList) void
compactRegion
(byte[] regionName) void
compactRegion
(byte[] regionName, byte[] columnFamily) void
compactRegionServer
(org.apache.hadoop.hbase.ServerName serverName) org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
coprocessorService
(org.apache.hadoop.hbase.ServerName serverName) createNamespaceAsync
(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) void
createTable
(org.apache.hadoop.hbase.client.TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) createTableAsync
(org.apache.hadoop.hbase.client.TableDescriptor desc) createTableAsync
(org.apache.hadoop.hbase.client.TableDescriptor desc, byte[][] splitKeys) void
decommissionRegionServers
(List<org.apache.hadoop.hbase.ServerName> servers, boolean offload) deleteColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) deleteNamespaceAsync
(String name) void
deleteSnapshot
(String snapshotName) void
deleteSnapshots
(Pattern pattern) deleteTableAsync
(org.apache.hadoop.hbase.TableName tableName) void
deleteTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) disableReplicationPeerAsync
(String peerId) disableTableAsync
(org.apache.hadoop.hbase.TableName tableName) void
disableTableReplication
(org.apache.hadoop.hbase.TableName tableName) enableReplicationPeerAsync
(String peerId) enableTableAsync
(org.apache.hadoop.hbase.TableName tableName) void
enableTableReplication
(org.apache.hadoop.hbase.TableName tableName) boolean
exceedThrottleQuotaSwitch
(boolean enable) void
byte[]
void
flush
(org.apache.hadoop.hbase.TableName tableName) void
flush
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) void
void
void
flushRegion
(byte[] regionName) void
flushRegion
(byte[] regionName, byte[] columnFamily) void
flushRegionServer
(org.apache.hadoop.hbase.ServerName serverName) getCachedFilesList
(org.apache.hadoop.hbase.ServerName serverName) org.apache.hadoop.hbase.ClusterMetrics
getClusterMetrics
(EnumSet<org.apache.hadoop.hbase.ClusterMetrics.Option> options) org.apache.hadoop.hbase.client.CompactionState
getCompactionState
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.CompactionState
getCompactionState
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) org.apache.hadoop.hbase.client.CompactionState
getCompactionStateForRegion
(byte[] regionName) org.apache.hadoop.conf.Configuration
getConfiguredNamespacesAndTablesInRSGroup
(String groupName) org.apache.hadoop.hbase.client.Connection
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
getCurrentSpaceQuotaSnapshot
(String namespace) org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
getCurrentSpaceQuotaSnapshot
(org.apache.hadoop.hbase.TableName tableName) org.apache.hadoop.hbase.client.TableDescriptor
getDescriptor
(org.apache.hadoop.hbase.TableName tableName) long
getLastMajorCompactionTimestamp
(org.apache.hadoop.hbase.TableName tableName) long
getLastMajorCompactionTimestampForRegion
(byte[] regionName) getLocks()
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) org.apache.hadoop.hbase.NamespaceDescriptor
getNamespaceDescriptor
(String name) int
List<org.apache.hadoop.hbase.quotas.QuotaSettings>
getQuota
(org.apache.hadoop.hbase.quotas.QuotaFilter filter) List<org.apache.hadoop.hbase.RegionMetrics>
getRegionMetrics
(org.apache.hadoop.hbase.ServerName serverName) List<org.apache.hadoop.hbase.RegionMetrics>
getRegionMetrics
(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.client.RegionInfo>
getRegions
(org.apache.hadoop.hbase.ServerName serverName) List<org.apache.hadoop.hbase.client.RegionInfo>
getRegions
(org.apache.hadoop.hbase.TableName tableName) Map<org.apache.hadoop.hbase.TableName,
? extends org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView> getRegionServerSpaceQuotaSnapshots
(org.apache.hadoop.hbase.ServerName serverName) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
getReplicationPeerConfig
(String peerId) org.apache.hadoop.hbase.rsgroup.RSGroupInfo
getRSGroup
(String groupName) org.apache.hadoop.hbase.rsgroup.RSGroupInfo
getRSGroup
(org.apache.hadoop.hbase.net.Address hostPort) org.apache.hadoop.hbase.rsgroup.RSGroupInfo
getRSGroup
(org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.client.security.SecurityCapability>
int
List<org.apache.hadoop.hbase.security.access.UserPermission>
getUserPermissions
(org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest getUserPermissionsRequest) void
grant
(org.apache.hadoop.hbase.security.access.UserPermission userPermission, boolean mergeExistingPermissions) hasUserPermissions
(String userName, List<org.apache.hadoop.hbase.security.access.Permission> permissions) boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
isReplicationPeerEnabled
(String peerId) boolean
boolean
boolean
boolean
isSnapshotFinished
(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) boolean
boolean
isTableAvailable
(org.apache.hadoop.hbase.TableName tableName) boolean
isTableDisabled
(org.apache.hadoop.hbase.TableName tableName) boolean
isTableEnabled
(org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.ServerName>
org.apache.hadoop.hbase.NamespaceDescriptor[]
String[]
List<org.apache.hadoop.hbase.client.replication.TableCFs>
List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription>
List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription>
listReplicationPeers
(Pattern pattern) List<org.apache.hadoop.hbase.rsgroup.RSGroupInfo>
List<org.apache.hadoop.hbase.client.SnapshotDescription>
List<org.apache.hadoop.hbase.client.SnapshotDescription>
listSnapshots
(Pattern pattern) List<org.apache.hadoop.hbase.client.TableDescriptor>
List<org.apache.hadoop.hbase.client.TableDescriptor>
listTableDescriptors
(boolean includeSysTables) List<org.apache.hadoop.hbase.client.TableDescriptor>
listTableDescriptors
(List<org.apache.hadoop.hbase.TableName> tableNames) List<org.apache.hadoop.hbase.client.TableDescriptor>
listTableDescriptors
(Pattern pattern, boolean includeSysTables) List<org.apache.hadoop.hbase.client.TableDescriptor>
listTableDescriptorsByNamespace
(byte[] name) List<org.apache.hadoop.hbase.client.TableDescriptor>
listTableDescriptorsByState
(boolean isEnabled) org.apache.hadoop.hbase.TableName[]
org.apache.hadoop.hbase.TableName[]
listTableNames
(Pattern pattern, boolean includeSysTables) org.apache.hadoop.hbase.TableName[]
List<org.apache.hadoop.hbase.TableName>
listTableNamesByState
(boolean isEnabled) List<org.apache.hadoop.hbase.TableName>
listTablesInRSGroup
(String groupName) List<org.apache.hadoop.hbase.client.SnapshotDescription>
listTableSnapshots
(Pattern tableNamePattern, Pattern snapshotNamePattern) void
majorCompact
(org.apache.hadoop.hbase.TableName tableName) void
majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily) void
majorCompact
(org.apache.hadoop.hbase.TableName tableName, byte[] columnFamily, org.apache.hadoop.hbase.client.CompactType compactType) void
majorCompact
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.CompactType compactType) void
majorCompactRegion
(byte[] regionName) void
majorCompactRegion
(byte[] regionName, byte[] columnFamily) void
majorCompactRegionServer
(org.apache.hadoop.hbase.ServerName serverName) mergeRegionsAsync
(byte[][] nameofRegionsToMerge, boolean forcible) boolean
mergeSwitch
(boolean enabled, boolean synchronous) modifyColumnFamilyAsync
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor columnFamily) modifyColumnFamilyStoreFileTrackerAsync
(org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) modifyNamespaceAsync
(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) modifyTableAsync
(org.apache.hadoop.hbase.client.TableDescriptor td) modifyTableAsync
(org.apache.hadoop.hbase.client.TableDescriptor td, boolean reopenRegions) modifyTableStoreFileTrackerAsync
(org.apache.hadoop.hbase.TableName tableName, String dstSFT) void
move
(byte[] encodedRegionName) void
move
(byte[] encodedRegionName, org.apache.hadoop.hbase.ServerName destServerName) void
moveServersToRSGroup
(Set<org.apache.hadoop.hbase.net.Address> servers, String targetGroup) boolean
normalize
(org.apache.hadoop.hbase.client.NormalizeTableFilterParams ntfp) boolean
normalizerSwitch
(boolean on) void
offline
(byte[] regionName) void
recommissionRegionServer
(org.apache.hadoop.hbase.ServerName server, List<byte[]> encodedRegionNames) removeReplicationPeerAsync
(String peerId) void
removeRSGroup
(String groupName) void
removeServersFromRSGroup
(Set<org.apache.hadoop.hbase.net.Address> servers) void
renameRSGroup
(String oldName, String newName) boolean
replicationPeerModificationSwitch
(boolean on, boolean drainProcedures) void
restoreSnapshot
(String snapshotName) void
restoreSnapshot
(String snapshotName, boolean takeFailSafeSnapshot, boolean restoreAcl) void
revoke
(org.apache.hadoop.hbase.security.access.UserPermission userPermission) void
rollWALWriter
(org.apache.hadoop.hbase.ServerName serverName) int
boolean
void
setQuota
(org.apache.hadoop.hbase.quotas.QuotaSettings quota) void
setRSGroup
(Set<org.apache.hadoop.hbase.TableName> tables, String groupName) void
shutdown()
void
snapshot
(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) snapshotAsync
(org.apache.hadoop.hbase.client.SnapshotDescription snapshot) boolean
snapshotCleanupSwitch
(boolean on, boolean synchronous) void
split
(org.apache.hadoop.hbase.TableName tableName) void
split
(org.apache.hadoop.hbase.TableName tableName, byte[] splitPoint) splitRegionAsync
(byte[] regionName) splitRegionAsync
(byte[] regionName, byte[] splitPoint) boolean
splitSwitch
(boolean enabled, boolean synchronous) void
void
stopRegionServer
(String hostnamePort) boolean
switchRpcThrottle
(boolean enable) boolean
tableExists
(org.apache.hadoop.hbase.TableName tableName) transitReplicationPeerSyncReplicationStateAsync
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) void
truncateRegion
(byte[] regionName) truncateRegionAsync
(byte[] regionName) truncateTableAsync
(org.apache.hadoop.hbase.TableName tableName, boolean preserveSplits) void
unassign
(byte[] regionName) void
void
updateConfiguration
(String groupName) void
updateConfiguration
(org.apache.hadoop.hbase.ServerName server) updateReplicationPeerConfigAsync
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
updateRSGroupConfig
(String groupName, Map<String, String> configuration) private void
verify()
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.hadoop.hbase.Abortable
abort
Methods inherited from interface org.apache.hadoop.hbase.client.Admin
abortProcedure, addColumnFamily, addReplicationPeer, addReplicationPeer, addReplicationPeerAsync, appendReplicationPeerTableCFs, balance, balance, balanceRSGroup, cloneSnapshot, cloneSnapshot, cloneSnapshot, cloneSnapshotAsync, cloneSnapshotAsync, createNamespace, createTable, createTable, deleteColumnFamily, deleteNamespace, deleteTable, disableReplicationPeer, disableTable, enableReplicationPeer, enableTable, getBackupMasters, getClusterMetrics, getMaster, getMasterCoprocessorNames, getMasterInfoPort, getRegionServers, getRegionServers, getReplicationPeerSyncReplicationState, getSlowLogResponses, hasUserPermissions, listDeadServers, listTableDescriptors, listTableNames, listUnknownServers, mergeRegionsAsync, modifyColumnFamily, modifyColumnFamilyStoreFileTracker, modifyNamespace, modifyTable, modifyTableStoreFileTracker, move, normalize, removeReplicationPeer, removeReplicationPeerTableCFs, replicationPeerModificationSwitch, restoreSnapshot, snapshot, snapshot, snapshot, snapshot, transitReplicationPeerSyncReplicationState, truncateTable, unassign, updateReplicationPeerConfig
-
Field Details
-
conn
-
admin
-
zkw
-
-
Constructor Details
-
VerifyingRSGroupAdmin
- Throws:
IOException
-
-
Method Details
-
getOperationTimeout
- Specified by:
getOperationTimeout
in interfaceorg.apache.hadoop.hbase.client.Admin
-
getSyncWaitTimeout
- Specified by:
getSyncWaitTimeout
in interfaceorg.apache.hadoop.hbase.client.Admin
-
abort
- Specified by:
abort
in interfaceorg.apache.hadoop.hbase.Abortable
- Specified by:
abort
in interfaceorg.apache.hadoop.hbase.client.Admin
-
isAborted
- Specified by:
isAborted
in interfaceorg.apache.hadoop.hbase.Abortable
- Specified by:
isAborted
in interfaceorg.apache.hadoop.hbase.client.Admin
-
getConnection
- Specified by:
getConnection
in interfaceorg.apache.hadoop.hbase.client.Admin
-
tableExists
- Specified by:
tableExists
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listTableDescriptors
public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors() throws IOException- Specified by:
listTableDescriptors
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listTableNames
- Specified by:
listTableNames
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listTableNamesByState
public List<org.apache.hadoop.hbase.TableName> listTableNamesByState(boolean isEnabled) throws IOException - Specified by:
listTableNamesByState
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
deleteTableAsync
public Future<Void> deleteTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException - Specified by:
deleteTableAsync
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
enableTableAsync
public Future<Void> enableTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException - Specified by:
enableTableAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
disableTableAsync
public Future<Void> disableTableAsync(org.apache.hadoop.hbase.TableName tableName) throws IOException - Specified by:
disableTableAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isTableEnabled
- Specified by:
isTableEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isTableDisabled
- Specified by:
isTableDisabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isTableAvailable
- Specified by:
isTableAvailable
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
flush
- Specified by:
flush
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
flushRegion
- Specified by:
flushRegion
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
flushRegion
- Specified by:
flushRegion
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
flushRegionServer
- Specified by:
flushRegionServer
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
compact
- Specified by:
compact
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
compactRegion
- Specified by:
compactRegion
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
compactRegion
- Specified by:
compactRegion
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
InterruptedException
-
majorCompact
- Specified by:
majorCompact
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
majorCompactRegion
- Specified by:
majorCompactRegion
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
majorCompactRegion
- Specified by:
majorCompactRegion
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
compactRegionServer
- Specified by:
compactRegionServer
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
majorCompactRegionServer
public void majorCompactRegionServer(org.apache.hadoop.hbase.ServerName serverName) throws IOException - Specified by:
majorCompactRegionServer
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
move
- Specified by:
move
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
assign
- Specified by:
assign
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
unassign
- Specified by:
unassign
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
offline
- Specified by:
offline
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
balancerSwitch
- Specified by:
balancerSwitch
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isBalancerEnabled
- Specified by:
isBalancerEnabled
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
normalize
public boolean normalize(org.apache.hadoop.hbase.client.NormalizeTableFilterParams ntfp) throws IOException - Specified by:
normalize
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isNormalizerEnabled
- Specified by:
isNormalizerEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
normalizerSwitch
- Specified by:
normalizerSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
catalogJanitorSwitch
- Specified by:
catalogJanitorSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
runCatalogJanitor
- Specified by:
runCatalogJanitor
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isCatalogJanitorEnabled
- Specified by:
isCatalogJanitorEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
cleanerChoreSwitch
- Specified by:
cleanerChoreSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
runCleanerChore
- Specified by:
runCleanerChore
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isCleanerChoreEnabled
- Specified by:
isCleanerChoreEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
mergeRegionsAsync
public Future<Void> mergeRegionsAsync(byte[][] nameofRegionsToMerge, boolean forcible) throws IOException - Specified by:
mergeRegionsAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
split
- Specified by:
split
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
splitRegionAsync
- Specified by:
splitRegionAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
splitRegionAsync
- Specified by:
splitRegionAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
truncateRegion
- Specified by:
truncateRegion
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
truncateRegionAsync
- Specified by:
truncateRegionAsync
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
shutdown
- Specified by:
shutdown
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
stopMaster
- Specified by:
stopMaster
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isMasterInMaintenanceMode
- Specified by:
isMasterInMaintenanceMode
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
stopRegionServer
- Specified by:
stopRegionServer
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getConfiguration
- Specified by:
getConfiguration
in interfaceorg.apache.hadoop.hbase.client.Admin
-
createNamespaceAsync
public Future<Void> createNamespaceAsync(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) throws IOException - Specified by:
createNamespaceAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
modifyNamespaceAsync
public Future<Void> modifyNamespaceAsync(org.apache.hadoop.hbase.NamespaceDescriptor descriptor) throws IOException - Specified by:
modifyNamespaceAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
deleteNamespaceAsync
- Specified by:
deleteNamespaceAsync
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
org.apache.hadoop.hbase.NamespaceNotFoundException
IOException
-
listNamespaces
- Specified by:
listNamespaces
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listNamespaceDescriptors
- Specified by:
listNamespaceDescriptors
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listTableNamesByNamespace
public org.apache.hadoop.hbase.TableName[] listTableNamesByNamespace(String name) throws IOException - Specified by:
listTableNamesByNamespace
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
close
- Specified by:
close
in interfaceorg.apache.hadoop.hbase.client.Admin
- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
-
listTableDescriptors
public List<org.apache.hadoop.hbase.client.TableDescriptor> listTableDescriptors(List<org.apache.hadoop.hbase.TableName> tableNames) throws IOException - Specified by:
listTableDescriptors
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
abortProcedureAsync
public Future<Boolean> abortProcedureAsync(long procId, boolean mayInterruptIfRunning) throws IOException - Specified by:
abortProcedureAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getProcedures
- Specified by:
getProcedures
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getLocks
- Specified by:
getLocks
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getCompactionStateForRegion
public org.apache.hadoop.hbase.client.CompactionState getCompactionStateForRegion(byte[] regionName) throws IOException - Specified by:
getCompactionStateForRegion
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getLastMajorCompactionTimestamp
public long getLastMajorCompactionTimestamp(org.apache.hadoop.hbase.TableName tableName) throws IOException - Specified by:
getLastMajorCompactionTimestamp
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getLastMajorCompactionTimestampForRegion
- Specified by:
getLastMajorCompactionTimestampForRegion
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listSnapshots
- Specified by:
listSnapshots
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
deleteSnapshot
- Specified by:
deleteSnapshot
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
deleteSnapshots
- Specified by:
deleteSnapshots
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
deleteTableSnapshots
public void deleteTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) throws IOException - Specified by:
deleteTableSnapshots
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
setQuota
- Specified by:
setQuota
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
coprocessorService
- Specified by:
coprocessorService
in interfaceorg.apache.hadoop.hbase.client.Admin
-
coprocessorService
public org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel coprocessorService(org.apache.hadoop.hbase.ServerName serverName) - Specified by:
coprocessorService
in interfaceorg.apache.hadoop.hbase.client.Admin
-
updateConfiguration
- Specified by:
updateConfiguration
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
updateConfiguration
- Specified by:
updateConfiguration
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
updateConfiguration
- Specified by:
updateConfiguration
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getSecurityCapabilities
public List<org.apache.hadoop.hbase.client.security.SecurityCapability> getSecurityCapabilities() throws IOException- Specified by:
getSecurityCapabilities
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
splitSwitch
- Specified by:
splitSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
mergeSwitch
- Specified by:
mergeSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isSplitEnabled
- Specified by:
isSplitEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isMergeEnabled
- Specified by:
isMergeEnabled
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
removeReplicationPeerAsync
- Specified by:
removeReplicationPeerAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
enableReplicationPeerAsync
- Specified by:
enableReplicationPeerAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
disableReplicationPeerAsync
- Specified by:
disableReplicationPeerAsync
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getReplicationPeerConfig
public org.apache.hadoop.hbase.replication.ReplicationPeerConfig getReplicationPeerConfig(String peerId) throws IOException - Specified by:
getReplicationPeerConfig
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listReplicationPeers
public List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription> listReplicationPeers() throws IOException- Specified by:
listReplicationPeers
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isReplicationPeerEnabled
- Specified by:
isReplicationPeerEnabled
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listDecommissionedRegionServers
public List<org.apache.hadoop.hbase.ServerName> listDecommissionedRegionServers() throws IOException- Specified by:
listDecommissionedRegionServers
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listReplicatedTableCFs
public List<org.apache.hadoop.hbase.client.replication.TableCFs> listReplicatedTableCFs() throws IOException- Specified by:
listReplicatedTableCFs
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
enableTableReplication
- Specified by:
enableTableReplication
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
disableTableReplication
- Specified by:
disableTableReplication
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
switchRpcThrottle
- Specified by:
switchRpcThrottle
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isRpcThrottleEnabled
- Specified by:
isRpcThrottleEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
exceedThrottleQuotaSwitch
- Specified by:
exceedThrottleQuotaSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getSpaceQuotaTableSizes
- Specified by:
getSpaceQuotaTableSizes
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getCurrentSpaceQuotaSnapshot
public org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView getCurrentSpaceQuotaSnapshot(String namespace) throws IOException - Specified by:
getCurrentSpaceQuotaSnapshot
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
snapshotCleanupSwitch
- Specified by:
snapshotCleanupSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isSnapshotCleanupEnabled
- Specified by:
isSnapshotCleanupEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
addRSGroup
- Specified by:
addRSGroup
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getRSGroup
- Specified by:
getRSGroup
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listRSGroups
- Specified by:
listRSGroups
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
listTablesInRSGroup
public List<org.apache.hadoop.hbase.TableName> listTablesInRSGroup(String groupName) throws IOException - Specified by:
listTablesInRSGroup
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
removeRSGroup
- Specified by:
removeRSGroup
in interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
renameRSGroup
- Specified by:
renameRSGroup
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
updateRSGroupConfig
public void updateRSGroupConfig(String groupName, Map<String, String> configuration) throws IOException- Specified by:
updateRSGroupConfig
in interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
verify
- Throws:
IOException
-
clearSlowLogResponses
public List<Boolean> clearSlowLogResponses(Set<org.apache.hadoop.hbase.ServerName> serverNames) throws IOException - Specified by:
clearSlowLogResponses
in interfaceorg.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 interfaceorg.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 interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
flushMasterStore
- Specified by:
flushMasterStore
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
getCachedFilesList
public List<String> getCachedFilesList(org.apache.hadoop.hbase.ServerName serverName) throws IOException - Specified by:
getCachedFilesList
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
replicationPeerModificationSwitch
public boolean replicationPeerModificationSwitch(boolean on, boolean drainProcedures) throws IOException - Specified by:
replicationPeerModificationSwitch
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-
isReplicationPeerModificationEnabled
- Specified by:
isReplicationPeerModificationEnabled
in interfaceorg.apache.hadoop.hbase.client.Admin
- Throws:
IOException
-