Class AdminOverAsyncAdmin
- All Implemented Interfaces:
Closeable,AutoCloseable,Abortable,Admin
Admin implementation which is based on an AsyncAdmin.-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionprivate static final class -
Field Summary
FieldsModifier and TypeFieldDescriptionprivate booleanprivate final RawAsyncHBaseAdminprivate final Connectionprivate static final org.slf4j.Loggerprivate final intprivate final int -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionvoidAbort the server or client.abortProcedureAsync(long procId, boolean mayInterruptIfRunning) Abort a procedure but does not block and wait for completion.addColumnFamilyAsync(TableName tableName, ColumnFamilyDescriptor columnFamily) Add a column family to an existing table.addReplicationPeerAsync(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer but does not block and wait for it.voidaddRSGroup(String groupName) Creates a new RegionServer group with the given namevoidassign(byte[] regionName) Assign a Region.booleanbalance()Invoke the balancer.booleanbalance(boolean force) Invoke the balancer.balance(BalanceRequest request) Invoke the balancer with the given balance request.balanceRSGroup(String groupName, BalanceRequest request) Balance regions in the given RegionServer group, running based on the givenBalanceRequest.booleanbalancerSwitch(boolean onOrOff, boolean synchronous) Turn the load balancer on or off.booleancatalogJanitorSwitch(boolean onOrOff) Enable/Disable the catalog janitor/booleancleanerChoreSwitch(boolean onOrOff) Enable/Disable the cleaner chore.clearBlockCache(TableName tableName) Clear all the blocks corresponding to this table from BlockCache.voidclearCompactionQueues(ServerName serverName, Set<String> queues) Clear compacting queues on a regionserver.clearDeadServers(List<ServerName> servers) Clear dead region servers from master.clearSlowLogResponses(Set<ServerName> serverNames) Clears online slow/large RPC logs from the provided list of RegionServerscloneSnapshotAsync(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) Create a new table by cloning the snapshot content.voidcloneTableSchema(TableName tableName, TableName newTableName, boolean preserveSplits) Create a new table by cloning the existent table schema.voidclose()voidCompact a table.voidCompact a column family within a table.voidcompact(TableName tableName, byte[] columnFamily, CompactType compactType) Compact a column family within a table.voidcompact(TableName tableName, CompactType compactType) Compact a table.compactionSwitch(boolean switchState, List<String> serverNamesList) Turn the compaction on or off.voidcompactRegion(byte[] regionName) Compact an individual region.voidcompactRegion(byte[] regionName, byte[] columnFamily) Compact a column family within a region.voidcompactRegionServer(ServerName serverName) Compact all regions on the region server.Creates and returns aRpcChannelinstance connected to the active master.coprocessorService(ServerName serverName) Creates and returns aRpcChannelinstance connected to the passed region server.createNamespaceAsync(NamespaceDescriptor descriptor) Create a new namespace.voidcreateTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) Creates a new table with the specified number of regions.Creates a new table but does not block and wait for it to come online.createTableAsync(TableDescriptor desc, byte[][] splitKeys) Creates a new table but does not block and wait for it to come online.voiddecommissionRegionServers(List<ServerName> servers, boolean offload) Mark region server(s) as decommissioned to prevent additional regions from getting assigned to them.deleteColumnFamilyAsync(TableName tableName, byte[] columnFamily) Delete a column family from a table.deleteNamespaceAsync(String name) Delete an existing namespace.voiddeleteSnapshot(String snapshotName) Delete an existing snapshot.voiddeleteSnapshots(Pattern pattern) Delete existing snapshots whose names match the pattern passed.deleteTableAsync(TableName tableName) Deletes the table but does not block and wait for it to be completely removed.voiddeleteTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) Delete all existing snapshots matching the given table name regular expression and snapshot name regular expression.disableReplicationPeerAsync(String peerId) Disable a replication peer but does not block and wait for it.disableTableAsync(TableName tableName) Disable the table but does not block and wait for it to be completely disabled.voiddisableTableReplication(TableName tableName) Disable a table's replication switch.enableReplicationPeerAsync(String peerId) Enable a replication peer but does not block and wait for it.enableTableAsync(TableName tableName) Enable the table but does not block and wait for it to be completely enabled.voidenableTableReplication(TableName tableName) Enable a table's replication switch.booleanexceedThrottleQuotaSwitch(boolean enable) Switch the exceed throttle quota.voidExecute a distributed procedure on a cluster.byte[]Execute a distributed procedure on a cluster.voidFlush a table.voidFlush the specified column family stores on all regions of the passed table.voidFlush the specified column family stores on all regions of the passed table.voidFlush master local regionvoidflushRegion(byte[] regionName) Flush an individual region.voidflushRegion(byte[] regionName, byte[] columnFamily) Flush a column family within a region.voidflushRegionServer(ServerName serverName) Flush all regions on the region server.getCachedFilesList(ServerName serverName) Get the list of cached filesgetClusterMetrics(EnumSet<ClusterMetrics.Option> options) Get cluster status with a set ofClusterMetrics.Optionto get desired status.getCompactionState(TableName tableName) Get the current compaction state of a table.getCompactionState(TableName tableName, CompactType compactType) Get the current compaction state of a table.getCompactionStateForRegion(byte[] regionName) Get the current compaction state of region.org.apache.hadoop.conf.ConfigurationReturns Configuration used by the instance.getConfiguredNamespacesAndTablesInRSGroup(String groupName) Get the namespaces and tables which have this RegionServer group in descriptor.Returns Connection used by this object.getCurrentSpaceQuotaSnapshot(String namespace) Returns the Master's view of a quota on the givennamespaceor null if the Master has no quota information on that namespace.getCurrentSpaceQuotaSnapshot(TableName tableName) Returns the Master's view of a quota on the giventableNameor null if the Master has no quota information on that table.getDescriptor(TableName tableName) Get a table descriptor.longgetLastMajorCompactionTimestamp(TableName tableName) Get the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.longgetLastMajorCompactionTimestampForRegion(byte[] regionName) Get the timestamp of the last major compaction for the passed region.getLocks()Get locks.getLogEntries(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) Retrieve recent online records from HMaster / RegionServers.getNamespaceDescriptor(String name) Get a namespace descriptor by name.intReturn the operation timeout for a rpc call.Get procedures.getQuota(QuotaFilter filter) List the quotas based on the filter.getRegionMetrics(ServerName serverName) GetRegionMetricsof all regions hosted on a regionserver.getRegionMetrics(ServerName serverName, TableName tableName) GetRegionMetricsof all regions hosted on a regionserver for a table.getRegions(ServerName serverName) Get all the online regions on a region server.getRegions(TableName tableName) Get the regions of a given table.Map<TableName,? extends SpaceQuotaSnapshotView> getRegionServerSpaceQuotaSnapshots(ServerName serverName) Fetches the observedSpaceQuotaSnapshotViews observed by a RegionServer.getReplicationPeerConfig(String peerId) Returns the configured ReplicationPeerConfig for the specified peer.getRSGroup(String groupName) Get group info for the given group namegetRSGroup(Address hostPort) Get group info for the given hostPortgetRSGroup(TableName tableName) Get group info for the given tableReturn the set of supported security capabilities.Fetches the table sizes on the filesystem as tracked by the HBase Master.intReturn the blocking wait time for an asynchronous operation.getUserPermissions(GetUserPermissionsRequest getUserPermissionsRequest) Get the global/namespace/table permissions for uservoidgrant(UserPermission userPermission, boolean mergeExistingPermissions) Grants user specific permissionshasUserPermissions(String userName, List<Permission> permissions) Check if the user has specific permissionsbooleanCheck if the server or client was aborted.booleanQuery the current state of the balancer.booleanQuery on the catalog janitor state (Enabled/Disabled?).booleanQuery on the cleaner chore state (Enabled/Disabled?).booleanCheck whether Master is in maintenance mode.booleanQuery the current state of the merge switch.booleanQuery the current state of the region normalizer.booleanCheck the current state of the specified procedure.booleanisReplicationPeerEnabled(String peerId) Check if a replication peer is enabled.booleanCheck whether replication peer modification is enabled.booleanGet if the rpc throttle is enabled.booleanQuery the current state of the auto snapshot cleanup based on TTL.booleanisSnapshotFinished(SnapshotDescription snapshot) Check the current state of the passed snapshot.booleanQuery the current state of the split switch.booleanisTableAvailable(TableName tableName) Check if a table is available.booleanisTableDisabled(TableName tableName) Check if a table is disabled.booleanisTableEnabled(TableName tableName) Check if a table is enabled.List region servers marked as decommissioned, which can not be assigned regions.List available namespace descriptorsString[]List available namespacesFind all table and column families that are replicated from this clusterReturn a list of replication peers.listReplicationPeers(Pattern pattern) Return a list of replication peers.Lists current set of RegionServer groupsList completed snapshots.listSnapshots(Pattern pattern) List all the completed snapshots matching the given pattern.List all the userspace tables.listTableDescriptors(boolean includeSysTables) List all userspace tables and whether or not include system tables.listTableDescriptors(List<TableName> tableNames) Get tableDescriptors.listTableDescriptors(Pattern pattern, boolean includeSysTables) List all the tables matching the given pattern.listTableDescriptorsByNamespace(byte[] name) Get list of table descriptors by namespace.listTableDescriptorsByState(boolean isEnabled) List all enabled or disabled tablesList all of the names of userspace tables.listTableNames(Pattern pattern, boolean includeSysTables) List all of the names of userspace tables.Get list of table names by namespace.listTableNamesByState(boolean isEnabled) List all enabled or disabled table nameslistTablesInRSGroup(String groupName) Get all tables in this RegionServer group.listTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) List all the completed snapshots matching the given table name regular expression and snapshot name regular expression.voidmajorCompact(TableName tableName) Major compact a table.voidmajorCompact(TableName tableName, byte[] columnFamily) Major compact a column family within a table.voidmajorCompact(TableName tableName, byte[] columnFamily, CompactType compactType) Major compact a column family within a table.voidmajorCompact(TableName tableName, CompactType compactType) Major compact a table.voidmajorCompactRegion(byte[] regionName) Major compact a table or an individual region.voidmajorCompactRegion(byte[] regionName, byte[] columnFamily) Major compact a column family within region.voidmajorCompactRegionServer(ServerName serverName) Major compact all regions on the region server.mergeRegionsAsync(byte[][] nameOfRegionsToMerge, boolean forcible) Merge multiple regions (>=2).booleanmergeSwitch(boolean enabled, boolean synchronous) Turn the merge switch on or off.modifyColumnFamilyAsync(TableName tableName, ColumnFamilyDescriptor columnFamily) Modify an existing column family on a table.modifyColumnFamilyStoreFileTrackerAsync(TableName tableName, byte[] family, String dstSFT) Change the store file tracker of the given table's given family.modifyNamespaceAsync(NamespaceDescriptor descriptor) Modify an existing namespace.Modify an existing table, more IRB (ruby) friendly version.modifyTableAsync(TableDescriptor td, boolean reopenRegions) The same asAdmin.modifyTableAsync(TableDescriptor td), except for the reopenRegions parameter, which controls whether the process of modifying the table should reopen all regions.modifyTableStoreFileTrackerAsync(TableName tableName, String dstSFT) Change the store file tracker of the given table.voidmove(byte[] encodedRegionName) Move the regionencodedRegionNameto a random server.voidmove(byte[] encodedRegionName, ServerName destServerName) Move the regionencodedRegionNametodestServerName.voidmoveServersToRSGroup(Set<Address> servers, String groupName) Move given set of servers to the specified target RegionServer groupbooleanInvoke region normalizer.booleannormalizerSwitch(boolean on) Turn region normalizer on or off.voidoffline(byte[] regionName) Offline specified region from master's in-memory state.voidrecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker from a region server to allow regions assignments.removeReplicationPeerAsync(String peerId) Remove a replication peer but does not block and wait for it.voidremoveRSGroup(String groupName) Remove RegionServer group associated with the given namevoidremoveServersFromRSGroup(Set<Address> servers) Remove decommissioned servers from group 1.voidrenameRSGroup(String oldName, String newName) Rename rsgroupbooleanreplicationPeerModificationSwitch(boolean on, boolean drainProcedures) Enable or disable replication peer modification.voidrestoreBackupSystemTable(String snapshotName) voidrestoreSnapshot(String snapshotName) Restore the specified snapshot on the original table.voidrestoreSnapshot(String snapshotName, boolean takeFailSafeSnapshot, boolean restoreAcl) Restore the specified snapshot on the original table.voidrevoke(UserPermission userPermission) Revokes user specific permissionsRoll log writer for all RegionServers.voidrollWALWriter(ServerName serverName) Roll the log writer.intAsk for a scan of the catalog table.booleanAsk for cleaner chore to run.voidsetQuota(QuotaSettings quota) Apply the new quota settings.voidsetRSGroup(Set<TableName> tables, String groupName) Set the RegionServer group for tablesvoidshutdown()Shuts down the HBase cluster.voidsnapshot(SnapshotDescription snapshot) Take a snapshot and wait for the server to complete that snapshot (blocking).snapshotAsync(SnapshotDescription snapshot) Take a snapshot without waiting for the server to complete that snapshot (asynchronous).booleansnapshotCleanupSwitch(boolean on, boolean synchronous) Turn on or off the auto snapshot cleanup based on TTL.voidSplit a table.voidSplit a table.splitRegionAsync(byte[] regionName) Split an individual region.splitRegionAsync(byte[] regionName, byte[] splitPoint) Split an individual region.booleansplitSwitch(boolean enabled, boolean synchronous) Turn the split switch on or off.voidShuts down the current HBase master only.voidstopRegionServer(String hostnamePort) Stop the designated regionserver.booleanswitchRpcThrottle(boolean enable) Switch the rpc throttle enable state.booleantableExists(TableName tableName) Check if a table exists.Transit current cluster to a new state in a synchronous replication peer.voidtruncateRegion(byte[] regionName) Truncate an individual region.truncateRegionAsync(byte[] regionName) Truncate an individual region.truncateTableAsync(TableName tableName, boolean preserveSplits) Truncate the table but does not block and wait for it to be completely enabled.voidunassign(byte[] regionName) Unassign a Region.voidUpdate the configuration and trigger an online config change on all the regionservers.voidupdateConfiguration(String groupName) Update the configuration and trigger an online config change on all the regionservers in the RSGroup.voidupdateConfiguration(ServerName server) Update the configuration and trigger an online config change on the regionserver.updateReplicationPeerConfigAsync(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer but does not block and wait for it.voidupdateRSGroupConfig(String groupName, Map<String, String> configuration) Update RSGroup configurationMethods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.client.Admin
abortProcedure, addColumnFamily, addReplicationPeer, addReplicationPeer, addReplicationPeerAsync, appendReplicationPeerTableCFs, 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
-
LOG
-
aborted
-
conn
-
admin
-
operationTimeout
-
syncWaitTimeout
-
-
Constructor Details
-
AdminOverAsyncAdmin
-
-
Method Details
-
getOperationTimeout
Description copied from interface:AdminReturn the operation timeout for a rpc call.- Specified by:
getOperationTimeoutin interfaceAdmin- See Also:
-
getSyncWaitTimeout
Description copied from interface:AdminReturn the blocking wait time for an asynchronous operation. Can be configured byhbase.client.sync.wait.timeout.msec. For several operations, such as createTable, deleteTable, etc, the rpc call will finish right after we schedule a procedure at master side, so the timeout will not be controlled by the aboveAdmin.getOperationTimeout(). And timeout value here tells you how much time we will wait until the procedure at master side is finished. In general, you can consider that the implementation for XXXX method is just a XXXXAsync().get(getSyncWaitTimeout(), TimeUnit.MILLISECONDS).- Specified by:
getSyncWaitTimeoutin interfaceAdmin- See Also:
-
abort
Description copied from interface:AbortableAbort the server or client. -
isAborted
Description copied from interface:AbortableCheck if the server or client was aborted. -
getConnection
Description copied from interface:AdminReturns Connection used by this object.- Specified by:
getConnectionin interfaceAdmin
-
tableExists
Description copied from interface:AdminCheck if a table exists.- Specified by:
tableExistsin interfaceAdmin- Parameters:
tableName- Table to check.- Returns:
trueif table exists already.- Throws:
IOException- if a remote or network exception occurs
-
listTableDescriptors
Description copied from interface:AdminList all the userspace tables.- Specified by:
listTableDescriptorsin interfaceAdmin- Returns:
- a list of TableDescriptors
- Throws:
IOException- if a remote or network exception occurs
-
listTableDescriptors
Description copied from interface:AdminList all userspace tables and whether or not include system tables.- Specified by:
listTableDescriptorsin interfaceAdmin- Returns:
- a list of TableDescriptors
- Throws:
IOException- if a remote or network exception occurs
-
listTableDescriptors
public List<TableDescriptor> listTableDescriptors(Pattern pattern, boolean includeSysTables) throws IOException Description copied from interface:AdminList all the tables matching the given pattern.- Specified by:
listTableDescriptorsin interfaceAdmin- Parameters:
pattern- The compiled regular expression to match againstincludeSysTables-falseto match only against userspace tables- Returns:
- a list of TableDescriptors
- Throws:
IOException- if a remote or network exception occurs- See Also:
-
listTableDescriptorsByState
Description copied from interface:AdminList all enabled or disabled tables- Specified by:
listTableDescriptorsByStatein interfaceAdmin- Parameters:
isEnabled- is true means return enabled tables, false means return disabled tables- Returns:
- a list of enabled or disabled tables
- Throws:
IOException
-
listTableNames
Description copied from interface:AdminList all of the names of userspace tables.- Specified by:
listTableNamesin interfaceAdmin- Returns:
- TableName[] table names
- Throws:
IOException- if a remote or network exception occurs
-
listTableNames
Description copied from interface:AdminList all of the names of userspace tables.- Specified by:
listTableNamesin interfaceAdmin- Parameters:
pattern- The regular expression to match againstincludeSysTables-falseto match only against userspace tables- Returns:
- TableName[] table names
- Throws:
IOException- if a remote or network exception occurs
-
listTableNamesByState
Description copied from interface:AdminList all enabled or disabled table names- Specified by:
listTableNamesByStatein interfaceAdmin- Parameters:
isEnabled- is true means return enabled table names, false means return disabled table names- Returns:
- a list of enabled or disabled table names
- Throws:
IOException
-
getDescriptor
public TableDescriptor getDescriptor(TableName tableName) throws TableNotFoundException, IOException Description copied from interface:AdminGet a table descriptor.- Specified by:
getDescriptorin interfaceAdmin- Parameters:
tableName- as aTableName- Returns:
- the tableDescriptor
- Throws:
TableNotFoundException- if the table was not foundIOException- if a remote or network exception occurs
-
createTable
public void createTable(TableDescriptor desc, byte[] startKey, byte[] endKey, int numRegions) throws IOException Description copied from interface:AdminCreates a new table with the specified number of regions. The start key specified will become the end key of the first region of the table, and the end key specified will become the start key of the last region of the table (the first region has a null start key and the last region has a null end key). BigInteger math will be used to divide the key range specified into enough segments to make the required number of total regions. Synchronous operation.- Specified by:
createTablein interfaceAdmin- Parameters:
desc- table descriptor for tablestartKey- beginning of key rangeendKey- end of key rangenumRegions- the total number of regions to create- Throws:
IOException- if a remote or network exception occursMasterNotRunningException- if master is not runningTableExistsException- if table already exists (If concurrent threads, the table may have been created between test-for-existence and attempt-at-creation).
-
createTableAsync
Description copied from interface:AdminCreates a new table but does not block and wait for it to come online. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete. Throws IllegalArgumentException Bad table name, if the split keys are repeated and if the split key has empty byte array.- Specified by:
createTableAsyncin interfaceAdmin- Parameters:
desc- table descriptor for table- Returns:
- the result of the async creation. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
createTableAsync
Description copied from interface:AdminCreates a new table but does not block and wait for it to come online. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete. Throws IllegalArgumentException Bad table name, if the split keys are repeated and if the split key has empty byte array.- Specified by:
createTableAsyncin interfaceAdmin- Parameters:
desc- table descriptor for tablesplitKeys- keys to check if the table has been created with all split keys- Returns:
- the result of the async creation. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
deleteTableAsync
Description copied from interface:AdminDeletes the table but does not block and wait for it to be completely removed. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
deleteTableAsyncin interfaceAdmin- Parameters:
tableName- name of table to delete- Returns:
- the result of the async delete. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
truncateTableAsync
public Future<Void> truncateTableAsync(TableName tableName, boolean preserveSplits) throws IOException Description copied from interface:AdminTruncate the table but does not block and wait for it to be completely enabled. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
truncateTableAsyncin interfaceAdmin- Parameters:
tableName- name of table to deletepreserveSplits-trueif the splits should be preserved- Returns:
- the result of the async truncate. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
enableTableAsync
Description copied from interface:AdminEnable the table but does not block and wait for it to be completely enabled. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
enableTableAsyncin interfaceAdmin- Parameters:
tableName- name of table to delete- Returns:
- the result of the async enable. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
disableTableAsync
Description copied from interface:AdminDisable the table but does not block and wait for it to be completely disabled. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
disableTableAsyncin interfaceAdmin- Parameters:
tableName- name of table to delete- Returns:
- the result of the async disable. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
isTableEnabled
Description copied from interface:AdminCheck if a table is enabled.- Specified by:
isTableEnabledin interfaceAdmin- Parameters:
tableName- name of table to check- Returns:
trueif table is on-line- Throws:
IOException- if a remote or network exception occurs
-
isTableDisabled
Description copied from interface:AdminCheck if a table is disabled.- Specified by:
isTableDisabledin interfaceAdmin- Parameters:
tableName- name of table to check- Returns:
trueif table is off-line- Throws:
IOException- if a remote or network exception occurs
-
isTableAvailable
Description copied from interface:AdminCheck if a table is available.- Specified by:
isTableAvailablein interfaceAdmin- Parameters:
tableName- name of table to check- Returns:
trueif all regions of the table are available- Throws:
IOException- if a remote or network exception occurs
-
addColumnFamilyAsync
public Future<Void> addColumnFamilyAsync(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException Description copied from interface:AdminAdd a column family to an existing table. Asynchronous operation. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
addColumnFamilyAsyncin interfaceAdmin- Parameters:
tableName- name of the table to add column family tocolumnFamily- column family descriptor of column family to be added- Returns:
- the result of the async add column family. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
deleteColumnFamilyAsync
public Future<Void> deleteColumnFamilyAsync(TableName tableName, byte[] columnFamily) throws IOException Description copied from interface:AdminDelete a column family from a table. Asynchronous operation. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
deleteColumnFamilyAsyncin interfaceAdmin- Parameters:
tableName- name of tablecolumnFamily- name of column family to be deleted- Returns:
- the result of the async delete column family. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
modifyColumnFamilyAsync
public Future<Void> modifyColumnFamilyAsync(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException Description copied from interface:AdminModify an existing column family on a table. Asynchronous operation. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
modifyColumnFamilyAsyncin interfaceAdmin- Parameters:
tableName- name of tablecolumnFamily- new column family descriptor to use- Returns:
- the result of the async modify column family. You can use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
modifyColumnFamilyStoreFileTrackerAsync
public Future<Void> modifyColumnFamilyStoreFileTrackerAsync(TableName tableName, byte[] family, String dstSFT) throws IOException Description copied from interface:AdminChange the store file tracker of the given table's given family.- Specified by:
modifyColumnFamilyStoreFileTrackerAsyncin interfaceAdmin- Parameters:
tableName- the table you want to changefamily- the family you want to changedstSFT- the destination store file tracker- Returns:
- the result of the async modify. You can use Future.get(long, TimeUnit) to wait on the operation to complete
- Throws:
IOException- if a remote or network exception occurs
-
getRegions
Description copied from interface:AdminGet all the online regions on a region server.- Specified by:
getRegionsin interfaceAdmin- Returns:
- List of
RegionInfo - Throws:
IOException- if a remote or network exception occurs
-
flush
Description copied from interface:AdminFlush a table. Synchronous operation.- Specified by:
flushin interfaceAdmin- Parameters:
tableName- table to flush- Throws:
IOException- if a remote or network exception occurs
-
flush
Description copied from interface:AdminFlush the specified column family stores on all regions of the passed table. This runs as a synchronous operation.- Specified by:
flushin interfaceAdmin- Parameters:
tableName- table to flushcolumnFamily- column family within a table- Throws:
IOException- if a remote or network exception occurs
-
flush
Description copied from interface:AdminFlush the specified column family stores on all regions of the passed table. This runs as a synchronous operation.- Specified by:
flushin interfaceAdmin- Parameters:
tableName- table to flushcolumnFamilies- column families within a table- Throws:
IOException- if a remote or network exception occurs
-
flushRegion
Description copied from interface:AdminFlush an individual region. Synchronous operation.- Specified by:
flushRegionin interfaceAdmin- Parameters:
regionName- region to flush- Throws:
IOException- if a remote or network exception occurs
-
flushRegion
Description copied from interface:AdminFlush a column family within a region. Synchronous operation.- Specified by:
flushRegionin interfaceAdmin- Parameters:
regionName- region to flushcolumnFamily- column family within a region- Throws:
IOException- if a remote or network exception occurs
-
flushRegionServer
Description copied from interface:AdminFlush all regions on the region server. Synchronous operation.- Specified by:
flushRegionServerin interfaceAdmin- Parameters:
serverName- the region server name to flush- Throws:
IOException- if a remote or network exception occurs
-
compact
Description copied from interface:AdminCompact a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactin interfaceAdmin- Parameters:
tableName- table to compact- Throws:
IOException- if a remote or network exception occurs
-
compactRegion
Description copied from interface:AdminCompact an individual region. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactRegionin interfaceAdmin- Parameters:
regionName- region to compact- Throws:
IOException- if a remote or network exception occurs
-
compact
Description copied from interface:AdminCompact a column family within a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactin interfaceAdmin- Parameters:
tableName- table to compactcolumnFamily- column family within a table- Throws:
IOException- if a remote or network exception occurs
-
compactRegion
Description copied from interface:AdminCompact a column family within a region. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactRegionin interfaceAdmin- Parameters:
regionName- region to compactcolumnFamily- column family within a region- Throws:
IOException- if a remote or network exception occurs
-
compact
public void compact(TableName tableName, CompactType compactType) throws IOException, InterruptedException Description copied from interface:AdminCompact a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactin interfaceAdmin- Parameters:
tableName- table to compactcompactType-CompactType- Throws:
IOException- if a remote or network exception occursInterruptedException
-
compact
public void compact(TableName tableName, byte[] columnFamily, CompactType compactType) throws IOException, InterruptedException Description copied from interface:AdminCompact a column family within a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactin interfaceAdmin- Parameters:
tableName- table to compactcolumnFamily- column family within a tablecompactType-CompactType- Throws:
IOException- if not a mob column family or if a remote or network exception occursInterruptedException
-
majorCompact
Description copied from interface:AdminMajor compact a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactin interfaceAdmin- Parameters:
tableName- table to major compact- Throws:
IOException- if a remote or network exception occurs
-
majorCompactRegion
Description copied from interface:AdminMajor compact a table or an individual region. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactRegionin interfaceAdmin- Parameters:
regionName- region to major compact- Throws:
IOException- if a remote or network exception occurs
-
majorCompact
Description copied from interface:AdminMajor compact a column family within a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactin interfaceAdmin- Parameters:
tableName- table to major compactcolumnFamily- column family within a table- Throws:
IOException- if a remote or network exception occurs
-
majorCompactRegion
Description copied from interface:AdminMajor compact a column family within region. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactRegionin interfaceAdmin- Parameters:
regionName- egion to major compactcolumnFamily- column family within a region- Throws:
IOException- if a remote or network exception occurs
-
majorCompact
public void majorCompact(TableName tableName, CompactType compactType) throws IOException, InterruptedException Description copied from interface:AdminMajor compact a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactin interfaceAdmin- Parameters:
tableName- table to compactcompactType-CompactType- Throws:
IOException- if a remote or network exception occursInterruptedException
-
majorCompact
public void majorCompact(TableName tableName, byte[] columnFamily, CompactType compactType) throws IOException, InterruptedException Description copied from interface:AdminMajor compact a column family within a table. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactin interfaceAdmin- Parameters:
tableName- table to compactcolumnFamily- column family within a tablecompactType-CompactType- Throws:
IOException- if not a mob column family or if a remote or network exception occursInterruptedException
-
compactionSwitch
public Map<ServerName,Boolean> compactionSwitch(boolean switchState, List<String> serverNamesList) throws IOException Description copied from interface:AdminTurn the compaction on or off. Disabling compactions will also interrupt any currently ongoing compactions. This state is ephemeral. The setting will be lost on restart. Compaction can also be enabled/disabled by modifying configuration hbase.regionserver.compaction.enabled in hbase-site.xml.- Specified by:
compactionSwitchin interfaceAdmin- Parameters:
switchState- Set totrueto enable,falseto disable.serverNamesList- list of region servers.- Returns:
- Previous compaction states for region servers
- Throws:
IOException- if a remote or network exception occurs
-
compactRegionServer
Description copied from interface:AdminCompact all regions on the region server. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
compactRegionServerin interfaceAdmin- Parameters:
serverName- the region server name- Throws:
IOException- if a remote or network exception occurs
-
majorCompactRegionServer
Description copied from interface:AdminMajor compact all regions on the region server. Asynchronous operation in that this method requests that a Compaction run and then it returns. It does not wait on the completion of Compaction (it can take a while).- Specified by:
majorCompactRegionServerin interfaceAdmin- Parameters:
serverName- the region server name- Throws:
IOException- if a remote or network exception occurs
-
move
Description copied from interface:AdminMove the regionencodedRegionNameto a random server.- Specified by:
movein interfaceAdmin- Parameters:
encodedRegionName- The encoded region name; i.e. the hash that makes up the region name suffix: e.g. if regionname isTestTable,0094429456,1289497600452.527db22f95c8a9e0116f0cc13c680396., then the encoded region name is:527db22f95c8a9e0116f0cc13c680396.- Throws:
IOException- if we can't find a region namedencodedRegionName
-
move
Description copied from interface:AdminMove the regionencodedRegionNametodestServerName.- Specified by:
movein interfaceAdmin- Parameters:
encodedRegionName- The encoded region name; i.e. the hash that makes up the region name suffix: e.g. if regionname isTestTable,0094429456,1289497600452.527db22f95c8a9e0116f0cc13c680396., then the encoded region name is:527db22f95c8a9e0116f0cc13c680396.destServerName- The servername of the destination regionserver. A server name is made of host, port and startcode. Here is an example:host187.example.com,60020,1289493121758- Throws:
IOException- if we can't find a region namedencodedRegionName
-
assign
Description copied from interface:AdminAssign a Region.- Specified by:
assignin interfaceAdmin- Parameters:
regionName- Region name to assign.- Throws:
IOException- if a remote or network exception occurs
-
unassign
Description copied from interface:AdminUnassign a Region.- Specified by:
unassignin interfaceAdmin- Parameters:
regionName- Region name to unassign.- Throws:
IOException- if a remote or network exception occurs
-
offline
Description copied from interface:AdminOffline specified region from master's in-memory state. It will not attempt to reassign the region as in unassign. This API can be used when a region not served by any region server and still online as per Master's in memory state. If this API is incorrectly used on active region then master will loose track of that region. This is a special method that should be used by experts or hbck.- Specified by:
offlinein interfaceAdmin- Parameters:
regionName- Region to offline.- Throws:
IOException- if a remote or network exception occurs
-
balancerSwitch
Description copied from interface:AdminTurn the load balancer on or off.- Specified by:
balancerSwitchin interfaceAdmin- Parameters:
onOrOff- Set totrueto enable,falseto disable.synchronous- Iftrue, it waits until current balance() call, if outstanding, to return.- Returns:
- Previous balancer value
- Throws:
IOException- if a remote or network exception occurs
-
balance
Description copied from interface:AdminInvoke the balancer with the given balance request. The BalanceRequest defines how the balancer will run. SeeBalanceRequestfor more details.- Specified by:
balancein interfaceAdmin- Parameters:
request- defines how the balancer should run- Returns:
BalanceResponsewith details about the results of the invocation.- Throws:
IOException- if a remote or network exception occurs
-
balance
Description copied from interface:AdminInvoke the balancer. Will run the balancer and if regions to move, it will go ahead and do the reassignments. Can NOT run for various reasons. Check logs.- Specified by:
balancein interfaceAdmin- Returns:
trueif balancer ran,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
balance
Description copied from interface:AdminInvoke the balancer. Will run the balancer and if regions to move, it will go ahead and do the reassignments. If there is region in transition, force parameter of true would still run balancer. Can *not* run for other reasons. Check logs.- Specified by:
balancein interfaceAdmin- Parameters:
force- whether we should force balance even if there is region in transition- Returns:
trueif balancer ran,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
isBalancerEnabled
Description copied from interface:AdminQuery the current state of the balancer.- Specified by:
isBalancerEnabledin interfaceAdmin- Returns:
trueif the balancer is enabled,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
clearBlockCache
Description copied from interface:AdminClear all the blocks corresponding to this table from BlockCache. For expert-admins. Calling this API will drop all the cached blocks specific to a table from BlockCache. This can significantly impact the query performance as the subsequent queries will have to retrieve the blocks from underlying filesystem.- Specified by:
clearBlockCachein interfaceAdmin- Parameters:
tableName- table to clear block cache- Returns:
- CacheEvictionStats related to the eviction
- Throws:
IOException- if a remote or network exception occurs
-
normalize
Description copied from interface:AdminInvoke region normalizer. Can NOT run for various reasons. Check logs. This is a non-blocking invocation to region normalizer. If return value is true, it means the request was submitted successfully. We need to check logs for the details of which regions were split/merged.- Specified by:
normalizein interfaceAdmin- Parameters:
ntfp- limit to tables matching the specified filter.- Returns:
trueif region normalizer ran,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
isNormalizerEnabled
Description copied from interface:AdminQuery the current state of the region normalizer.- Specified by:
isNormalizerEnabledin interfaceAdmin- Returns:
trueif region normalizer is enabled,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
normalizerSwitch
Description copied from interface:AdminTurn region normalizer on or off.- Specified by:
normalizerSwitchin interfaceAdmin- Returns:
- Previous normalizer value
- Throws:
IOException- if a remote or network exception occurs
-
catalogJanitorSwitch
Description copied from interface:AdminEnable/Disable the catalog janitor/- Specified by:
catalogJanitorSwitchin interfaceAdmin- Parameters:
onOrOff- iftrueenables the catalog janitor- Returns:
- the previous state
- Throws:
IOException- if a remote or network exception occurs
-
runCatalogJanitor
Description copied from interface:AdminAsk for a scan of the catalog table.- Specified by:
runCatalogJanitorin interfaceAdmin- Returns:
- the number of entries cleaned. Returns -1 if previous run is in progress.
- Throws:
IOException- if a remote or network exception occurs
-
isCatalogJanitorEnabled
Description copied from interface:AdminQuery on the catalog janitor state (Enabled/Disabled?).- Specified by:
isCatalogJanitorEnabledin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
cleanerChoreSwitch
Description copied from interface:AdminEnable/Disable the cleaner chore.- Specified by:
cleanerChoreSwitchin interfaceAdmin- Parameters:
onOrOff- iftrueenables the cleaner chore- Returns:
- the previous state
- Throws:
IOException- if a remote or network exception occurs
-
runCleanerChore
Description copied from interface:AdminAsk for cleaner chore to run.- Specified by:
runCleanerChorein interfaceAdmin- Returns:
trueif cleaner chore ran,falseotherwise- Throws:
IOException- if a remote or network exception occurs
-
isCleanerChoreEnabled
Description copied from interface:AdminQuery on the cleaner chore state (Enabled/Disabled?).- Specified by:
isCleanerChoreEnabledin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
mergeRegionsAsync
public Future<Void> mergeRegionsAsync(byte[][] nameOfRegionsToMerge, boolean forcible) throws IOException Description copied from interface:AdminMerge multiple regions (>=2). Asynchronous operation.- Specified by:
mergeRegionsAsyncin interfaceAdmin- Parameters:
nameOfRegionsToMerge- encoded or full name of daughter regionsforcible-trueif do a compulsory merge, otherwise we will only merge adjacent regions- Throws:
IOException- if a remote or network exception occurs
-
split
Description copied from interface:AdminSplit a table. The method will execute split action for each region in table.- Specified by:
splitin interfaceAdmin- Parameters:
tableName- table to split- Throws:
IOException- if a remote or network exception occurs
-
split
Description copied from interface:AdminSplit a table.- Specified by:
splitin interfaceAdmin- Parameters:
tableName- table to splitsplitPoint- the explicit position to split on- Throws:
IOException- if a remote or network exception occurs
-
splitRegionAsync
Description copied from interface:AdminSplit an individual region. Asynchronous operation.- Specified by:
splitRegionAsyncin interfaceAdmin- Parameters:
regionName- region to split- Throws:
IOException- if a remote or network exception occurs
-
splitRegionAsync
Description copied from interface:AdminSplit an individual region. Asynchronous operation.- Specified by:
splitRegionAsyncin interfaceAdmin- Parameters:
regionName- region to splitsplitPoint- the explicit position to split on- Throws:
IOException- if a remote or network exception occurs
-
truncateRegion
Description copied from interface:AdminTruncate an individual region.- Specified by:
truncateRegionin interfaceAdmin- Parameters:
regionName- region to truncate- Throws:
IOException- if a remote or network exception occurs
-
truncateRegionAsync
Description copied from interface:AdminTruncate an individual region. Asynchronous operation.- Specified by:
truncateRegionAsyncin interfaceAdmin- Parameters:
regionName- region to truncate
-
modifyTableAsync
Description copied from interface:AdminModify an existing table, more IRB (ruby) friendly version. Asynchronous operation. This means that it may be a while before your schema change is updated across all of the table. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
modifyTableAsyncin interfaceAdmin- Parameters:
td- description of the table- Returns:
- the result of the async modify. You can use Future.get(long, TimeUnit) to wait on the operation to complete
- Throws:
IOException- if a remote or network exception occurs
-
modifyTableAsync
Description copied from interface:AdminThe same asAdmin.modifyTableAsync(TableDescriptor td), except for the reopenRegions parameter, which controls whether the process of modifying the table should reopen all regions.- Specified by:
modifyTableAsyncin interfaceAdmin- Parameters:
td- description of the tablereopenRegions- By default, 'modifyTable' reopens all regions, potentially causing a RIT (Region In Transition) storm in large tables. If set to 'false', regions will remain unaware of the modification until they are individually reopened. Please note that this may temporarily result in configuration inconsistencies among regions.- Returns:
- the result of the async modify. You can use Future.get(long, TimeUnit) to wait on the operation to complete
- Throws:
IOException- if a remote or network exception occurs
-
modifyTableStoreFileTrackerAsync
public Future<Void> modifyTableStoreFileTrackerAsync(TableName tableName, String dstSFT) throws IOException Description copied from interface:AdminChange the store file tracker of the given table.- Specified by:
modifyTableStoreFileTrackerAsyncin interfaceAdmin- Parameters:
tableName- the table you want to changedstSFT- the destination store file tracker- Returns:
- the result of the async modify. You can use Future.get(long, TimeUnit) to wait on the operation to complete
- Throws:
IOException- if a remote or network exception occurs
-
shutdown
Description copied from interface:AdminShuts down the HBase cluster. Notice that, a success shutdown call may ends with an error since the remote server has already been shutdown.- Specified by:
shutdownin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
stopMaster
Description copied from interface:AdminShuts down the current HBase master only. Does not shutdown the cluster. Notice that, a success stopMaster call may ends with an error since the remote server has already been shutdown.- Specified by:
stopMasterin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs- See Also:
-
isMasterInMaintenanceMode
Description copied from interface:AdminCheck whether Master is in maintenance mode.- Specified by:
isMasterInMaintenanceModein interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
stopRegionServer
Description copied from interface:AdminStop the designated regionserver.- Specified by:
stopRegionServerin interfaceAdmin- Parameters:
hostnamePort- Hostname and port delimited by a:as inexample.org:1234- Throws:
IOException- if a remote or network exception occurs
-
getClusterMetrics
Description copied from interface:AdminGet cluster status with a set ofClusterMetrics.Optionto get desired status.- Specified by:
getClusterMetricsin interfaceAdmin- Returns:
- cluster status
- Throws:
IOException- if a remote or network exception occurs
-
getRegionMetrics
Description copied from interface:AdminGetRegionMetricsof all regions hosted on a regionserver.- Specified by:
getRegionMetricsin interfaceAdmin- Parameters:
serverName- region server from whichRegionMetricsis required.- Returns:
- a
RegionMetricslist of all regions hosted on a region server - Throws:
IOException- if a remote or network exception occurs
-
getRegionMetrics
public List<RegionMetrics> getRegionMetrics(ServerName serverName, TableName tableName) throws IOException Description copied from interface:AdminGetRegionMetricsof all regions hosted on a regionserver for a table.- Specified by:
getRegionMetricsin interfaceAdmin- Parameters:
serverName- region server from whichRegionMetricsis required.tableName- getRegionMetricsof regions belonging to the table- Returns:
- region metrics map of all regions of a table hosted on a region server
- Throws:
IOException- if a remote or network exception occurs
-
getConfiguration
Description copied from interface:AdminReturns Configuration used by the instance.- Specified by:
getConfigurationin interfaceAdmin
-
createNamespaceAsync
Description copied from interface:AdminCreate a new namespace.- Specified by:
createNamespaceAsyncin interfaceAdmin- Parameters:
descriptor- descriptor which describes the new namespace- Returns:
- the result of the async create namespace operation. Use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
modifyNamespaceAsync
Description copied from interface:AdminModify an existing namespace.- Specified by:
modifyNamespaceAsyncin interfaceAdmin- Parameters:
descriptor- descriptor which describes the new namespace- Returns:
- the result of the async modify namespace operation. Use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
deleteNamespaceAsync
Description copied from interface:AdminDelete an existing namespace. Only empty namespaces (no tables) can be removed.- Specified by:
deleteNamespaceAsyncin interfaceAdmin- Parameters:
name- namespace name- Returns:
- the result of the async delete namespace operation. Use Future.get(long, TimeUnit) to wait on the operation to complete.
- Throws:
IOException- if a remote or network exception occurs
-
getNamespaceDescriptor
public NamespaceDescriptor getNamespaceDescriptor(String name) throws NamespaceNotFoundException, IOException Description copied from interface:AdminGet a namespace descriptor by name.- Specified by:
getNamespaceDescriptorin interfaceAdmin- Parameters:
name- name of namespace descriptor- Returns:
- A descriptor
- Throws:
NamespaceNotFoundException- if the namespace was not foundIOException- if a remote or network exception occurs
-
listNamespaces
Description copied from interface:AdminList available namespaces- Specified by:
listNamespacesin interfaceAdmin- Returns:
- List of namespace names
- Throws:
IOException- if a remote or network exception occurs
-
listNamespaceDescriptors
Description copied from interface:AdminList available namespace descriptors- Specified by:
listNamespaceDescriptorsin interfaceAdmin- Returns:
- List of descriptors
- Throws:
IOException- if a remote or network exception occurs
-
listTableDescriptorsByNamespace
Description copied from interface:AdminGet list of table descriptors by namespace.- Specified by:
listTableDescriptorsByNamespacein interfaceAdmin- Parameters:
name- namespace name- Returns:
- returns a list of TableDescriptors
- Throws:
IOException- if a remote or network exception occurs
-
listTableNamesByNamespace
Description copied from interface:AdminGet list of table names by namespace.- Specified by:
listTableNamesByNamespacein interfaceAdmin- Parameters:
name- namespace name- Returns:
- The list of table names in the namespace
- Throws:
IOException- if a remote or network exception occurs
-
getRegions
Description copied from interface:AdminGet the regions of a given table.- Specified by:
getRegionsin interfaceAdmin- Parameters:
tableName- the name of the table- Returns:
- List of
RegionInfo. - Throws:
IOException- if a remote or network exception occurs
-
close
-
listTableDescriptors
Description copied from interface:AdminGet tableDescriptors.- Specified by:
listTableDescriptorsin interfaceAdmin- Parameters:
tableNames- List of table names- Returns:
- returns a list of TableDescriptors
- Throws:
IOException- if a remote or network exception occurs
-
abortProcedureAsync
public Future<Boolean> abortProcedureAsync(long procId, boolean mayInterruptIfRunning) throws IOException Description copied from interface:AdminAbort a procedure but does not block and wait for completion. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete. Do not use. Usually it is ignored but if not, it can do more damage than good. See hbck2.- Specified by:
abortProcedureAsyncin interfaceAdmin- Parameters:
procId- ID of the procedure to abortmayInterruptIfRunning- if the proc completed at least one step, should it be aborted?- Returns:
trueif aborted,falseif procedure already completed or does not exist- Throws:
IOException- if a remote or network exception occurs- See Also:
-
getProcedures
Description copied from interface:AdminGet procedures.- Specified by:
getProceduresin interfaceAdmin- Returns:
- procedure list in JSON
- Throws:
IOException- if a remote or network exception occurs
-
getLocks
Description copied from interface:AdminGet locks.- Specified by:
getLocksin interfaceAdmin- Returns:
- lock list in JSON
- Throws:
IOException- if a remote or network exception occurs
-
rollWALWriter
Description copied from interface:AdminRoll the log writer. I.e. for filesystem based write ahead logs, start writing to a new file. Note that the actual rolling of the log writer is asynchronous and may not be complete when this method returns. As a side effect of this call, the named region server may schedule store flushes at the request of the wal.- Specified by:
rollWALWriterin interfaceAdmin- Parameters:
serverName- The servername of the regionserver.- Throws:
IOException- if a remote or network exception occursFailedLogCloseException- if we failed to close the WAL
-
rollAllWALWriters
Description copied from interface:AdminRoll log writer for all RegionServers. Note that unlikeAdmin.rollWALWriter(ServerName), this method is synchronous, which means it will block until all RegionServers have completed the log roll, or a RegionServer fails due to an exception that retry will not work.- Specified by:
rollAllWALWritersin interfaceAdmin- Returns:
- server and the highest wal filenum of server before performing log roll
- Throws:
IOException- if a remote or network exception occurs
-
getCompactionState
Description copied from interface:AdminGet the current compaction state of a table. It could be in a major compaction, a minor compaction, both, or none.- Specified by:
getCompactionStatein interfaceAdmin- Parameters:
tableName- table to examine- Returns:
- the current compaction state
- Throws:
IOException- if a remote or network exception occurs
-
getCompactionState
public CompactionState getCompactionState(TableName tableName, CompactType compactType) throws IOException Description copied from interface:AdminGet the current compaction state of a table. It could be in a compaction, or none.- Specified by:
getCompactionStatein interfaceAdmin- Parameters:
tableName- table to examinecompactType-CompactType- Returns:
- the current compaction state
- Throws:
IOException- if a remote or network exception occurs
-
getCompactionStateForRegion
Description copied from interface:AdminGet the current compaction state of region. It could be in a major compaction, a minor compaction, both, or none.- Specified by:
getCompactionStateForRegionin interfaceAdmin- Parameters:
regionName- region to examine- Returns:
- the current compaction state
- Throws:
IOException- if a remote or network exception occurs
-
getLastMajorCompactionTimestamp
Description copied from interface:AdminGet the timestamp of the last major compaction for the passed table The timestamp of the oldest HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.- Specified by:
getLastMajorCompactionTimestampin interfaceAdmin- Parameters:
tableName- table to examine- Returns:
- the last major compaction timestamp or 0
- Throws:
IOException- if a remote or network exception occurs
-
getLastMajorCompactionTimestampForRegion
Description copied from interface:AdminGet the timestamp of the last major compaction for the passed region. The timestamp of the oldest HFile resulting from a major compaction of that region, or 0 if no such HFile could be found.- Specified by:
getLastMajorCompactionTimestampForRegionin interfaceAdmin- Parameters:
regionName- region to examine- Returns:
- the last major compaction timestamp or 0
- Throws:
IOException- if a remote or network exception occurs
-
snapshot
public void snapshot(SnapshotDescription snapshot) throws IOException, SnapshotCreationException, IllegalArgumentException Description copied from interface:AdminTake a snapshot and wait for the server to complete that snapshot (blocking). Snapshots are considered unique based on the name of the snapshot. Snapshots are taken sequentially even when requested concurrently, across all tables. Attempts to take a snapshot with the same name (even a different type or with different parameters) will fail with aSnapshotCreationExceptionindicating the duplicate naming. Snapshot names follow the same naming constraints as tables in HBase. SeeTableName.isLegalFullyQualifiedTableName(byte[]). You should probably useAdmin.snapshot(String, org.apache.hadoop.hbase.TableName)unless you are sure about the type of snapshot that you want to take.- Specified by:
snapshotin interfaceAdmin- Parameters:
snapshot- snapshot to take- Throws:
IOException- or we lose contact with the master.SnapshotCreationException- if snapshot failed to be takenIllegalArgumentException- if the snapshot request is formatted incorrectly
-
snapshotAsync
public Future<Void> snapshotAsync(SnapshotDescription snapshot) throws IOException, SnapshotCreationException Description copied from interface:AdminTake a snapshot without waiting for the server to complete that snapshot (asynchronous). Snapshots are considered unique based on the name of the snapshot. Snapshots are taken sequentially even when requested concurrently, across all tables.- Specified by:
snapshotAsyncin interfaceAdmin- Parameters:
snapshot- snapshot to take- Throws:
IOException- if the snapshot did not succeed or we lose contact with the master.SnapshotCreationException- if snapshot creation failed
-
isSnapshotFinished
public boolean isSnapshotFinished(SnapshotDescription snapshot) throws IOException, HBaseSnapshotException, UnknownSnapshotException Description copied from interface:AdminCheck the current state of the passed snapshot. There are three possible states:- running - returns false
- finished - returns true
- finished with error - throws the exception that caused the snapshot to fail
UnknownSnapshotException.- Specified by:
isSnapshotFinishedin interfaceAdmin- Parameters:
snapshot- description of the snapshot to check- Returns:
- true if the snapshot is completed, false if the snapshot is still running
- Throws:
IOException- if we have a network issueHBaseSnapshotException- if the snapshot failedUnknownSnapshotException- if the requested snapshot is unknown
-
restoreSnapshot
Description copied from interface:AdminRestore the specified snapshot on the original table. (The table must be disabled) If the "hbase.snapshot.restore.take.failsafe.snapshot" configuration property is set totrue, a snapshot of the current table is taken before executing the restore operation. In case of restore failure, the failsafe snapshot will be restored. If the restore completes without problem the failsafe snapshot is deleted.- Specified by:
restoreSnapshotin interfaceAdmin- Parameters:
snapshotName- name of the snapshot to restore- Throws:
IOException- if a remote or network exception occursRestoreSnapshotException- if snapshot failed to be restored
-
restoreSnapshot
public void restoreSnapshot(String snapshotName, boolean takeFailSafeSnapshot, boolean restoreAcl) throws IOException, RestoreSnapshotException Description copied from interface:AdminRestore the specified snapshot on the original table. (The table must be disabled) If 'takeFailSafeSnapshot' is set totrue, a snapshot of the current table is taken before executing the restore operation. In case of restore failure, the failsafe snapshot will be restored. If the restore completes without problem the failsafe snapshot is deleted. The failsafe snapshot name is configurable by using the property "hbase.snapshot.restore.failsafe.name".- Specified by:
restoreSnapshotin interfaceAdmin- Parameters:
snapshotName- name of the snapshot to restoretakeFailSafeSnapshot-trueif the failsafe snapshot should be takenrestoreAcl-trueto restore acl of snapshot- Throws:
IOException- if a remote or network exception occursRestoreSnapshotException- if snapshot failed to be restored
-
cloneSnapshotAsync
public Future<Void> cloneSnapshotAsync(String snapshotName, TableName tableName, boolean restoreAcl, String customSFT) throws IOException, TableExistsException, RestoreSnapshotException Description copied from interface:AdminCreate a new table by cloning the snapshot content.- Specified by:
cloneSnapshotAsyncin interfaceAdmin- Parameters:
snapshotName- name of the snapshot to be clonedtableName- name of the table where the snapshot will be restoredrestoreAcl-trueto clone acl into newly created tablecustomSFT- specify the StroreFileTracker used for the table- Throws:
IOException- if a remote or network exception occursTableExistsException- if table to be created already existsRestoreSnapshotException- if snapshot failed to be cloned
-
execProcedure
public void execProcedure(String signature, String instance, Map<String, String> props) throws IOExceptionDescription copied from interface:AdminExecute a distributed procedure on a cluster.- Specified by:
execProcedurein interfaceAdmin- Parameters:
signature- A distributed procedure is uniquely identified by its signature (default the root ZK node name of the procedure).instance- The instance name of the procedure. For some procedures, this parameter is optional.props- Property/Value pairs of properties passing to the procedure- Throws:
IOException- if a remote or network exception occurs
-
execProcedureWithReturn
public byte[] execProcedureWithReturn(String signature, String instance, Map<String, String> props) throws IOExceptionDescription copied from interface:AdminExecute a distributed procedure on a cluster.- Specified by:
execProcedureWithReturnin interfaceAdmin- Parameters:
signature- A distributed procedure is uniquely identified by its signature (default the root ZK node name of the procedure).instance- The instance name of the procedure. For some procedures, this parameter is optional.props- Property/Value pairs of properties passing to the procedure- Returns:
- data returned after procedure execution. null if no return data.
- Throws:
IOException- if a remote or network exception occurs
-
isProcedureFinished
public boolean isProcedureFinished(String signature, String instance, Map<String, String> props) throws IOExceptionDescription copied from interface:AdminCheck the current state of the specified procedure. There are three possible states:- running - returns false
- finished - returns true
- finished with error - throws the exception that caused the procedure to fail
- Specified by:
isProcedureFinishedin interfaceAdmin- Parameters:
signature- The signature that uniquely identifies a procedureinstance- The instance name of the procedureprops- Property/Value pairs of properties passing to the procedure- Returns:
trueif the specified procedure is finished successfully,falseif it is still running- Throws:
IOException- if the specified procedure finished with error
-
listSnapshots
Description copied from interface:AdminList completed snapshots.- Specified by:
listSnapshotsin interfaceAdmin- Returns:
- a list of snapshot descriptors for completed snapshots
- Throws:
IOException- if a network error occurs
-
listSnapshots
Description copied from interface:AdminList all the completed snapshots matching the given pattern.- Specified by:
listSnapshotsin interfaceAdmin- Parameters:
pattern- The compiled regular expression to match against- Returns:
- list of SnapshotDescription
- Throws:
IOException- if a remote or network exception occurs
-
listTableSnapshots
public List<SnapshotDescription> listTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) throws IOException Description copied from interface:AdminList all the completed snapshots matching the given table name regular expression and snapshot name regular expression.- Specified by:
listTableSnapshotsin interfaceAdmin- Parameters:
tableNamePattern- The compiled table name regular expression to match againstsnapshotNamePattern- The compiled snapshot name regular expression to match against- Returns:
- list of completed SnapshotDescription
- Throws:
IOException- if a remote or network exception occurs
-
deleteSnapshot
Description copied from interface:AdminDelete an existing snapshot.- Specified by:
deleteSnapshotin interfaceAdmin- Parameters:
snapshotName- name of the snapshot- Throws:
IOException- if a remote or network exception occurs
-
deleteSnapshots
Description copied from interface:AdminDelete existing snapshots whose names match the pattern passed.- Specified by:
deleteSnapshotsin interfaceAdmin- Parameters:
pattern- pattern for names of the snapshot to match- Throws:
IOException- if a remote or network exception occurs
-
deleteTableSnapshots
public void deleteTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) throws IOException Description copied from interface:AdminDelete all existing snapshots matching the given table name regular expression and snapshot name regular expression.- Specified by:
deleteTableSnapshotsin interfaceAdmin- Parameters:
tableNamePattern- The compiled table name regular expression to match againstsnapshotNamePattern- The compiled snapshot name regular expression to match against- Throws:
IOException- if a remote or network exception occurs
-
setQuota
Description copied from interface:AdminApply the new quota settings.- Specified by:
setQuotain interfaceAdmin- Parameters:
quota- the quota settings- Throws:
IOException- if a remote or network exception occurs
-
getQuota
Description copied from interface:AdminList the quotas based on the filter.- Specified by:
getQuotain interfaceAdmin- Parameters:
filter- the quota settings filter- Returns:
- the QuotaSetting list
- Throws:
IOException- if a remote or network exception occurs
-
coprocessorService
Description copied from interface:AdminCreates and returns aRpcChannelinstance connected to the active master. The obtainedRpcChannelinstance can be used to access a published coprocessorServiceusing standard protobuf service invocations:CoprocessorRpcChannel channel = myAdmin.coprocessorService(); MyService.BlockingInterface service = MyService.newBlockingStub(channel); MyCallRequest request = MyCallRequest.newBuilder() ... .build(); MyCallResponse response = service.myCall(null, request);- Specified by:
coprocessorServicein interfaceAdmin- Returns:
- A MasterCoprocessorRpcChannel instance
-
coprocessorService
Description copied from interface:AdminCreates and returns aRpcChannelinstance connected to the passed region server. The obtainedRpcChannelinstance can be used to access a published coprocessorServiceusing standard protobuf service invocations:CoprocessorRpcChannel channel = myAdmin.coprocessorService(serverName); MyService.BlockingInterface service = MyService.newBlockingStub(channel); MyCallRequest request = MyCallRequest.newBuilder() ... .build(); MyCallResponse response = service.myCall(null, request);- Specified by:
coprocessorServicein interfaceAdmin- Parameters:
serverName- the server name to which the endpoint call is made- Returns:
- A RegionServerCoprocessorRpcChannel instance
-
updateConfiguration
Description copied from interface:AdminUpdate the configuration and trigger an online config change on the regionserver.- Specified by:
updateConfigurationin interfaceAdmin- Parameters:
server- : The server whose config needs to be updated.- Throws:
IOException- if a remote or network exception occurs
-
updateConfiguration
Description copied from interface:AdminUpdate the configuration and trigger an online config change on all the regionservers.- Specified by:
updateConfigurationin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
updateConfiguration
Description copied from interface:AdminUpdate the configuration and trigger an online config change on all the regionservers in the RSGroup.- Specified by:
updateConfigurationin interfaceAdmin- Parameters:
groupName- the group name- Throws:
IOException- if a remote or network exception occurs
-
getSecurityCapabilities
Description copied from interface:AdminReturn the set of supported security capabilities.- Specified by:
getSecurityCapabilitiesin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
splitSwitch
Description copied from interface:AdminTurn the split switch on or off.- Specified by:
splitSwitchin interfaceAdmin- Parameters:
enabled- enabled or notsynchronous- Iftrue, it waits until current split() call, if outstanding, to return.- Returns:
- Previous switch value
- Throws:
IOException- if a remote or network exception occurs
-
mergeSwitch
Description copied from interface:AdminTurn the merge switch on or off.- Specified by:
mergeSwitchin interfaceAdmin- Parameters:
enabled- enabled or notsynchronous- Iftrue, it waits until current merge() call, if outstanding, to return.- Returns:
- Previous switch value
- Throws:
IOException- if a remote or network exception occurs
-
isSplitEnabled
Description copied from interface:AdminQuery the current state of the split switch.- Specified by:
isSplitEnabledin interfaceAdmin- Returns:
trueif the switch is enabled,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
isMergeEnabled
Description copied from interface:AdminQuery the current state of the merge switch.- Specified by:
isMergeEnabledin interfaceAdmin- Returns:
trueif the switch is enabled,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
addReplicationPeerAsync
public Future<Void> addReplicationPeerAsync(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) throws IOException Description copied from interface:AdminAdd a new replication peer but does not block and wait for it.You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.
- Specified by:
addReplicationPeerAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peerpeerConfig- configuration for the replication peerenabled- peer state, true if ENABLED and false if DISABLED- Returns:
- the result of the async operation
- Throws:
IOException- IOException if a remote or network exception occurs
-
removeReplicationPeerAsync
Description copied from interface:AdminRemove a replication peer but does not block and wait for it.You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.
- Specified by:
removeReplicationPeerAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peer- Returns:
- the result of the async operation
- Throws:
IOException- IOException if a remote or network exception occurs
-
enableReplicationPeerAsync
Description copied from interface:AdminEnable a replication peer but does not block and wait for it.You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.
- Specified by:
enableReplicationPeerAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peer- Returns:
- the result of the async operation
- Throws:
IOException- IOException if a remote or network exception occurs
-
disableReplicationPeerAsync
Description copied from interface:AdminDisable a replication peer but does not block and wait for it. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
disableReplicationPeerAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peer- Returns:
- the result of the async operation
- Throws:
IOException- IOException if a remote or network exception occurs
-
getReplicationPeerConfig
Description copied from interface:AdminReturns the configured ReplicationPeerConfig for the specified peer.- Specified by:
getReplicationPeerConfigin interfaceAdmin- Parameters:
peerId- a short name that identifies the peer- Returns:
- ReplicationPeerConfig for the peer
- Throws:
IOException- if a remote or network exception occurs
-
updateReplicationPeerConfigAsync
public Future<Void> updateReplicationPeerConfigAsync(String peerId, ReplicationPeerConfig peerConfig) throws IOException Description copied from interface:AdminUpdate the peerConfig for the specified peer but does not block and wait for it. You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.- Specified by:
updateReplicationPeerConfigAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peerpeerConfig- new config for the replication peer- Returns:
- the result of the async operation
- Throws:
IOException- IOException if a remote or network exception occurs
-
listReplicationPeers
Description copied from interface:AdminReturn a list of replication peers.- Specified by:
listReplicationPeersin interfaceAdmin- Returns:
- a list of replication peers description
- Throws:
IOException- if a remote or network exception occurs
-
listReplicationPeers
Description copied from interface:AdminReturn a list of replication peers.- Specified by:
listReplicationPeersin interfaceAdmin- Parameters:
pattern- The compiled regular expression to match peer id- Returns:
- a list of replication peers description
- Throws:
IOException- if a remote or network exception occurs
-
transitReplicationPeerSyncReplicationStateAsync
public Future<Void> transitReplicationPeerSyncReplicationStateAsync(String peerId, SyncReplicationState state) throws IOException Description copied from interface:AdminTransit current cluster to a new state in a synchronous replication peer. But does not block and wait for it.You can use Future.get(long, TimeUnit) to wait on the operation to complete. It may throw ExecutionException if there was an error while executing the operation or TimeoutException in case the wait timeout was not long enough to allow the operation to complete.
- Specified by:
transitReplicationPeerSyncReplicationStateAsyncin interfaceAdmin- Parameters:
peerId- a short name that identifies the peerstate- a new state of current cluster- Throws:
IOException- if a remote or network exception occurs
-
isReplicationPeerEnabled
Description copied from interface:AdminCheck if a replication peer is enabled.- Specified by:
isReplicationPeerEnabledin interfaceAdmin- Parameters:
peerId- id of replication peer to check- Returns:
trueif replication peer is enabled- Throws:
IOException- if a remote or network exception occurs
-
replicationPeerModificationSwitch
public boolean replicationPeerModificationSwitch(boolean on, boolean drainProcedures) throws IOException Description copied from interface:AdminEnable or disable replication peer modification. This is especially useful when you want to change the replication peer storage.- Specified by:
replicationPeerModificationSwitchin interfaceAdmin- Parameters:
on-truemeans enable, otherwise disabledrainProcedures- iftrue, will wait until all the running replication peer modification procedures finish- Returns:
- the previous enable/disable state
- Throws:
IOException
-
isReplicationPeerModificationEnabled
Description copied from interface:AdminCheck whether replication peer modification is enabled.- Specified by:
isReplicationPeerModificationEnabledin interfaceAdmin- Returns:
trueif modification is enabled, otherwisefalse- Throws:
IOException
-
decommissionRegionServers
Description copied from interface:AdminMark region server(s) as decommissioned to prevent additional regions from getting assigned to them. Optionally unload the regions on the servers. If there are multiple servers to be decommissioned, decommissioning them at the same time can prevent wasteful region movements. Region unloading is asynchronous.- Specified by:
decommissionRegionServersin interfaceAdmin- Parameters:
servers- The list of servers to decommission.offload- True to offload the regions from the decommissioned servers- Throws:
IOException- if a remote or network exception occurs
-
listDecommissionedRegionServers
Description copied from interface:AdminList region servers marked as decommissioned, which can not be assigned regions.- Specified by:
listDecommissionedRegionServersin interfaceAdmin- Returns:
- List of decommissioned region servers.
- Throws:
IOException- if a remote or network exception occurs
-
recommissionRegionServer
public void recommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) throws IOException Description copied from interface:AdminRemove decommission marker from a region server to allow regions assignments. Load regions onto the server if a list of regions is given. Region loading is asynchronous.- Specified by:
recommissionRegionServerin interfaceAdmin- Parameters:
server- The server to recommission.encodedRegionNames- Regions to load onto the server.- Throws:
IOException- if a remote or network exception occurs
-
listReplicatedTableCFs
Description copied from interface:AdminFind all table and column families that are replicated from this cluster- Specified by:
listReplicatedTableCFsin interfaceAdmin- Returns:
- the replicated table-cfs list of this cluster.
- Throws:
IOException- if a remote or network exception occurs
-
enableTableReplication
Description copied from interface:AdminEnable a table's replication switch.- Specified by:
enableTableReplicationin interfaceAdmin- Parameters:
tableName- name of the table- Throws:
IOException- if a remote or network exception occurs
-
disableTableReplication
Description copied from interface:AdminDisable a table's replication switch.- Specified by:
disableTableReplicationin interfaceAdmin- Parameters:
tableName- name of the table- Throws:
IOException- if a remote or network exception occurs
-
clearCompactionQueues
public void clearCompactionQueues(ServerName serverName, Set<String> queues) throws IOException, InterruptedException Description copied from interface:AdminClear compacting queues on a regionserver.- Specified by:
clearCompactionQueuesin interfaceAdmin- Parameters:
serverName- the region server namequeues- the set of queue name- Throws:
IOException- if a remote or network exception occursInterruptedException
-
clearDeadServers
Description copied from interface:AdminClear dead region servers from master.- Specified by:
clearDeadServersin interfaceAdmin- Parameters:
servers- list of dead region servers.- Returns:
- List of servers that are not cleared
- Throws:
IOException- if a remote or network exception occurs
-
cloneTableSchema
public void cloneTableSchema(TableName tableName, TableName newTableName, boolean preserveSplits) throws IOException Description copied from interface:AdminCreate a new table by cloning the existent table schema.- Specified by:
cloneTableSchemain interfaceAdmin- Parameters:
tableName- name of the table to be clonednewTableName- name of the new table where the table will be createdpreserveSplits- True if the splits should be preserved- Throws:
IOException- if a remote or network exception occurs
-
switchRpcThrottle
Description copied from interface:AdminSwitch the rpc throttle enable state.- Specified by:
switchRpcThrottlein interfaceAdmin- Parameters:
enable- Set totrueto enable,falseto disable.- Returns:
- Previous rpc throttle enabled value
- Throws:
IOException- if a remote or network exception occurs
-
isRpcThrottleEnabled
Description copied from interface:AdminGet if the rpc throttle is enabled.- Specified by:
isRpcThrottleEnabledin interfaceAdmin- Returns:
- True if rpc throttle is enabled
- Throws:
IOException- if a remote or network exception occurs
-
exceedThrottleQuotaSwitch
Description copied from interface:AdminSwitch the exceed throttle quota. If enabled, user/table/namespace throttle quota can be exceeded if region server has availble quota.- Specified by:
exceedThrottleQuotaSwitchin interfaceAdmin- Parameters:
enable- Set totrueto enable,falseto disable.- Returns:
- Previous exceed throttle enabled value
- Throws:
IOException- if a remote or network exception occurs
-
getSpaceQuotaTableSizes
Description copied from interface:AdminFetches the table sizes on the filesystem as tracked by the HBase Master.- Specified by:
getSpaceQuotaTableSizesin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
getRegionServerSpaceQuotaSnapshots
public Map<TableName,? extends SpaceQuotaSnapshotView> getRegionServerSpaceQuotaSnapshots(ServerName serverName) throws IOException Description copied from interface:AdminFetches the observedSpaceQuotaSnapshotViews observed by a RegionServer.- Specified by:
getRegionServerSpaceQuotaSnapshotsin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
getCurrentSpaceQuotaSnapshot
Description copied from interface:AdminReturns the Master's view of a quota on the givennamespaceor null if the Master has no quota information on that namespace.- Specified by:
getCurrentSpaceQuotaSnapshotin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
getCurrentSpaceQuotaSnapshot
Description copied from interface:AdminReturns the Master's view of a quota on the giventableNameor null if the Master has no quota information on that table.- Specified by:
getCurrentSpaceQuotaSnapshotin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
grant
public void grant(UserPermission userPermission, boolean mergeExistingPermissions) throws IOException Description copied from interface:AdminGrants user specific permissions- Specified by:
grantin interfaceAdmin- Parameters:
userPermission- user name and the specific permissionmergeExistingPermissions- If set to false, later granted permissions will override previous granted permissions. otherwise, it'll merge with previous granted permissions.- Throws:
IOException- if a remote or network exception occurs
-
revoke
Description copied from interface:AdminRevokes user specific permissions- Specified by:
revokein interfaceAdmin- Parameters:
userPermission- user name and the specific permission- Throws:
IOException- if a remote or network exception occurs
-
getUserPermissions
public List<UserPermission> getUserPermissions(GetUserPermissionsRequest getUserPermissionsRequest) throws IOException Description copied from interface:AdminGet the global/namespace/table permissions for user- Specified by:
getUserPermissionsin interfaceAdmin- Parameters:
getUserPermissionsRequest- A request contains which user, global, namespace or table permissions needed- Returns:
- The user and permission list
- Throws:
IOException- if a remote or network exception occurs
-
hasUserPermissions
public List<Boolean> hasUserPermissions(String userName, List<Permission> permissions) throws IOException Description copied from interface:AdminCheck if the user has specific permissions- Specified by:
hasUserPermissionsin interfaceAdmin- Parameters:
userName- the user namepermissions- the specific permission list- Returns:
- True if user has the specific permissions
- Throws:
IOException- if a remote or network exception occurs
-
snapshotCleanupSwitch
Description copied from interface:AdminTurn on or off the auto snapshot cleanup based on TTL.- Specified by:
snapshotCleanupSwitchin interfaceAdmin- Parameters:
on- Set totrueto enable,falseto disable.synchronous- Iftrue, it waits until current snapshot cleanup is completed, if outstanding.- Returns:
- Previous auto snapshot cleanup value
- Throws:
IOException- if a remote or network exception occurs
-
isSnapshotCleanupEnabled
Description copied from interface:AdminQuery the current state of the auto snapshot cleanup based on TTL.- Specified by:
isSnapshotCleanupEnabledin interfaceAdmin- Returns:
trueif the auto snapshot cleanup is enabled,falseotherwise.- Throws:
IOException- if a remote or network exception occurs
-
clearSlowLogResponses
Description copied from interface:AdminClears online slow/large RPC logs from the provided list of RegionServers- Specified by:
clearSlowLogResponsesin interfaceAdmin- Parameters:
serverNames- Set of Server names to clean slowlog responses from- Returns:
- List of booleans representing if online slowlog response buffer is cleaned from each RegionServer
- Throws:
IOException- if a remote or network exception occurs
-
getRSGroup
Description copied from interface:AdminGet group info for the given group name- Specified by:
getRSGroupin interfaceAdmin- Parameters:
groupName- the group name- Returns:
- group info
- Throws:
IOException- if a remote or network exception occurs
-
moveServersToRSGroup
Description copied from interface:AdminMove given set of servers to the specified target RegionServer group- Specified by:
moveServersToRSGroupin interfaceAdmin- Parameters:
servers- set of servers to movegroupName- the group to move servers to- Throws:
IOException- if a remote or network exception occurs
-
addRSGroup
Description copied from interface:AdminCreates a new RegionServer group with the given name- Specified by:
addRSGroupin interfaceAdmin- Parameters:
groupName- the name of the group- Throws:
IOException- if a remote or network exception occurs
-
removeRSGroup
Description copied from interface:AdminRemove RegionServer group associated with the given name- Specified by:
removeRSGroupin interfaceAdmin- Parameters:
groupName- the group name- Throws:
IOException- if a remote or network exception occurs
-
balanceRSGroup
Description copied from interface:AdminBalance regions in the given RegionServer group, running based on the givenBalanceRequest.- Specified by:
balanceRSGroupin interfaceAdmin- Returns:
- BalanceResponse details about the balancer run
- Throws:
IOException
-
listRSGroups
Description copied from interface:AdminLists current set of RegionServer groups- Specified by:
listRSGroupsin interfaceAdmin- Throws:
IOException- if a remote or network exception occurs
-
listTablesInRSGroup
Description copied from interface:AdminGet all tables in this RegionServer group.- Specified by:
listTablesInRSGroupin interfaceAdmin- Parameters:
groupName- the group name- Throws:
IOException- if a remote or network exception occurs- See Also:
-
getConfiguredNamespacesAndTablesInRSGroup
public Pair<List<String>,List<TableName>> getConfiguredNamespacesAndTablesInRSGroup(String groupName) throws IOException Description copied from interface:AdminGet the namespaces and tables which have this RegionServer group in descriptor. The difference between this method andAdmin.listTablesInRSGroup(String)is that, this method will not include the table which is actually in this RegionServr group but without the RegionServer group configuration in itsTableDescriptor. For example, we have a group 'A', and we make namespace 'nsA' in this group, then all the tables under this namespace will in the group 'A', but this method will not return these tables but only the namespace 'nsA', while theAdmin.listTablesInRSGroup(String)will return all these tables.- Specified by:
getConfiguredNamespacesAndTablesInRSGroupin interfaceAdmin- Parameters:
groupName- the group name- Throws:
IOException- if a remote or network exception occurs- See Also:
-
getRSGroup
Description copied from interface:AdminGet group info for the given hostPort- Specified by:
getRSGroupin interfaceAdmin- Parameters:
hostPort- HostPort to get RSGroupInfo for- Throws:
IOException- if a remote or network exception occurs
-
removeServersFromRSGroup
Description copied from interface:AdminRemove decommissioned servers from group 1. Sometimes we may find the server aborted due to some hardware failure and we must offline the server for repairing. Or we need to move some servers to join other clusters. So we need to remove these servers from the group. 2. Dead/recovering/live servers will be disallowed.- Specified by:
removeServersFromRSGroupin interfaceAdmin- Parameters:
servers- set of servers to remove- Throws:
IOException- if a remote or network exception occurs
-
getRSGroup
Description copied from interface:AdminGet group info for the given table- Specified by:
getRSGroupin interfaceAdmin- Parameters:
tableName- table name to get RSGroupInfo for- Throws:
IOException- if a remote or network exception occurs
-
setRSGroup
Description copied from interface:AdminSet the RegionServer group for tables- Specified by:
setRSGroupin interfaceAdmin- Parameters:
tables- tables to set group forgroupName- group name for tables- Throws:
IOException- if a remote or network exception occurs
-
renameRSGroup
Description copied from interface:AdminRename rsgroup- Specified by:
renameRSGroupin interfaceAdmin- Parameters:
oldName- old rsgroup namenewName- new rsgroup name- Throws:
IOException- if a remote or network exception occurs
-
updateRSGroupConfig
public void updateRSGroupConfig(String groupName, Map<String, String> configuration) throws IOExceptionDescription copied from interface:AdminUpdate RSGroup configuration- Specified by:
updateRSGroupConfigin interfaceAdmin- Parameters:
groupName- the group nameconfiguration- new configuration of the group name to be set- Throws:
IOException- if a remote or network exception occurs
-
getLogEntries
public List<LogEntry> getLogEntries(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) throws IOExceptionDescription copied from interface:AdminRetrieve recent online records from HMaster / RegionServers. Examples include slow/large RPC logs, balancer decisions by master.- Specified by:
getLogEntriesin interfaceAdmin- Parameters:
serverNames- servers to retrieve records from, useful in case of records maintained by RegionServer as we can select specific server. In case of servertype=MASTER, logs will only come from the currently active master.logType- string representing type of log recordsserverType- enum for server type: HMaster or RegionServerlimit- put a limit to list of records that server should send in responsefilterParams- additional filter params- Returns:
- Log entries representing online records from servers
- Throws:
IOException- if a remote or network exception occurs
-
flushMasterStore
Description copied from interface:AdminFlush master local region- Specified by:
flushMasterStorein interfaceAdmin- Throws:
IOException
-
getCachedFilesList
Description copied from interface:AdminGet the list of cached files- Specified by:
getCachedFilesListin interfaceAdmin- Throws:
IOException
-
restoreBackupSystemTable
- Specified by:
restoreBackupSystemTablein interfaceAdmin- Throws:
IOException
-