Uses of Class
org.apache.hadoop.hbase.HBaseIOException
Package
Description
Provides HBase Client
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
Table of Contents
Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
-
Uses of HBaseIOException in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionclass
Returned to the clients when their request was discarded due to server being overloaded.class
Returned to clients when their request was dropped because the call queue was too big to accept a new call.class
Thrown when a table has been modified concurrentlyclass
Subclass if exception is not meant to be retried: e.g.class
Base class for exceptions thrown by an HBase server.class
Thrown if a request is table schema modification is requested but made for an invalid family name.class
Thrown if the master is not runningclass
Thrown when a namespace exists but should notclass
Thrown when a namespace can not be locatedclass
Thrown when an operation requires the root and all meta regions to be onlineclass
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.class
Thrown if the master requires restart.class
Thrown when something happens related to region handling.class
Thrown when a replication peer can not be foundclass
class
Thrown when a table exists but should not.class
Failed to find.tableinfo
file under the table directory.class
Thrown if a table should be offline but is not.class
Thrown if a table should be enabled but is not.class
Thrown when a table cannot be located.class
Thrown when we are asked to operate on a region we know nothing about.class
Thrown if a region server is passed an unknown scanner ID. -
Uses of HBaseIOException in org.apache.hadoop.hbase.backup.impl
Modifier and TypeClassDescriptionclass
Backup exceptionfinal class
-
Uses of HBaseIOException in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
Similar to RegionException, but disables retries.class
Thrown when no region server can be found for a regionclass
Thrown when a table can not be locatedclass
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).class
-
Uses of HBaseIOException in org.apache.hadoop.hbase.codec
Modifier and TypeClassDescriptionclass
Thrown when problems in the codec whether setup or context. -
Uses of HBaseIOException in org.apache.hadoop.hbase.constraint
Modifier and TypeClassDescriptionclass
Exception that a user defined constraint throws on failure of aPut
. -
Uses of HBaseIOException in org.apache.hadoop.hbase.coprocessor
Modifier and TypeClassDescriptionclass
Thrown if a coprocessor encounters any exception. -
Uses of HBaseIOException in org.apache.hadoop.hbase.exceptions
Modifier and TypeClassDescriptionclass
Thrown when the connection is closedclass
Exception thrown if a mutation fails sanity checks.class
Exception thrown when an master registry RPC fails in client.class
Thrown when the master is stoppedclass
Thrown when something is wrong in trying to merge two regions.class
Thrown by a RegionServer while doing next() calls on a ResultScanner.class
Thrown when the size of the rpc request received by the server is too large.class
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.class
class
An error requesting an RPC protocol that the server is not serving. -
Uses of HBaseIOException in org.apache.hadoop.hbase.favored
Modifier and TypeMethodDescriptionFavoredNodeLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) FavoredNodeLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) -
Uses of HBaseIOException in org.apache.hadoop.hbase.fs
Modifier and TypeMethodDescriptionprivate static void
ErasureCodingUtils.checkAvailable
(org.apache.hadoop.hdfs.DistributedFileSystem dfs, String policy) private static org.apache.hadoop.fs.Path
ErasureCodingUtils.createTempDir
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tempDir) private static org.apache.hadoop.hdfs.DistributedFileSystem
ErasureCodingUtils.getDfs
(org.apache.hadoop.conf.Configuration conf) static void
ErasureCodingUtils.verifySupport
(org.apache.hadoop.conf.Configuration conf, String policy) Runs checks against the FileSystem, verifying that HDFS is supported and the policy is available, enabled, and works with a simple write. -
Uses of HBaseIOException in org.apache.hadoop.hbase.io.hfile
Modifier and TypeClassDescriptionclass
This exception is thrown when attempts to read an HFile fail due to corruption or truncation issues. -
Uses of HBaseIOException in org.apache.hadoop.hbase.ipc
Modifier and TypeClassDescriptionclass
class
Client side call cancelled.class
Client-side call timeoutclass
Thrown if a cellscanner but no codec to encode it with.class
class
class
Indicates that we're trying to connect to a already known as dead server.class
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.class
Thrown when server finds fatal issue w/ connection setup: e.g.class
Will be thrown when server received a security preamble call for asking the server principal but security is not enabled for this server.class
Throw this in RPC call if there are too many pending requests for one region serverclass
class
class
class
class
class
-
Uses of HBaseIOException in org.apache.hadoop.hbase.master
-
Uses of HBaseIOException in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionprivate void
AssignmentManager.acceptPlan
(HashMap<RegionInfo, RegionStateNode> regions, Map<ServerName, List<RegionInfo>> plan) Future<byte[]>
AssignmentManager.balance
(RegionPlan regionPlan) AssignmentManager.createMoveRegionProcedure
(RegionInfo regionInfo, ServerName targetServer) Future<byte[]>
AssignmentManager.moveAsync
(RegionPlan regionPlan) private void
AssignmentManager.preTransitCheck
(RegionStateNode regionNode, RegionState.State[] expectedStates) -
Uses of HBaseIOException in org.apache.hadoop.hbase.master.balancer
Modifier and TypeMethodDescriptionprivate BalancerClusterState
BaseLoadBalancer.createCluster
(List<ServerName> servers, Collection<RegionInfo> regions) BaseLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.FavoredStochasticBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) If we have favored nodes for a region, we will return one of the FN as destination.BaseLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Generates a bulk assignment startup plan, attempting to reuse the existing assignment information from META, but adjusting for the specified list of available/online servers available for assignment.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.BaseLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.FavoredStochasticBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Round robin assignment: Segregate the regions into two types: 1.private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes. -
Uses of HBaseIOException in org.apache.hadoop.hbase.master.procedure
Modifier and TypeClassDescriptionclass
Passed as Exception byServerCrashProcedure
notifying on-going RIT that server has failed.Modifier and TypeMethodDescriptionprotected void
AbstractStateMachineTableProcedure.preflightChecks
(MasterProcedureEnv env, Boolean enabled) Check that cluster is up and master is running.protected void
FlushTableProcedure.preflightChecks
(MasterProcedureEnv env, Boolean enabled) protected void
ModifyTableProcedure.preflightChecks
(MasterProcedureEnv env, Boolean enabled) ModifierConstructorDescriptionDisableTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean skipTableStateCheck) ConstructorDisableTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean skipTableStateCheck, ProcedurePrepareLatch syncLatch) ConstructorModifyTableProcedure
(MasterProcedureEnv env, TableDescriptor htd, ProcedurePrepareLatch latch) ModifyTableProcedure
(MasterProcedureEnv env, TableDescriptor newTableDescriptor, ProcedurePrepareLatch latch, TableDescriptor oldTableDescriptor, boolean shouldCheckDescriptor, boolean reopenRegions) RestoreSnapshotProcedure
(MasterProcedureEnv env, TableDescriptor oldTableDescriptor, TableDescriptor modifiedTableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl) ConstructorRestoreSnapshotProcedure
(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) RestoreSnapshotProcedure
(MasterProcedureEnv env, TableDescriptor tableDescriptor, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, boolean restoreAcl) TruncateRegionProcedure
(MasterProcedureEnv env, RegionInfo region, ProcedurePrepareLatch latch) TruncateTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean preserveSplits) TruncateTableProcedure
(MasterProcedureEnv env, TableName tableName, boolean preserveSplits, ProcedurePrepareLatch latch) -
Uses of HBaseIOException in org.apache.hadoop.hbase.procedure2
Modifier and TypeClassDescriptionclass
class
Used internally signaling failed queue of a remote procedure operation.class
Used internally signaling failed queue of a remote procedure operation.class
Used internally signaling failed queue of a remote procedure operation.class
Used internally signaling failed queue of a remote procedure operation. -
Uses of HBaseIOException in org.apache.hadoop.hbase.procedure2.store.region
Modifier and TypeMethodDescriptionprivate void
RegionProcedureStore.checkUnsupportedProcedure
(Map<Class<?>, List<Procedure<?>>> procsByType) In HBASE-20811, we have introduced a new TRSP to assign/unassign/move regions, and it is incompatible with the old AssignProcedure/UnassignProcedure/MoveRegionProcedure. -
Uses of HBaseIOException in org.apache.hadoop.hbase.procedure2.store.wal
Modifier and TypeClassDescriptionclass
Deprecated.Since 2.3.0, will be removed in 4.0.0. -
Uses of HBaseIOException in org.apache.hadoop.hbase.quotas
Modifier and TypeClassDescriptionclass
Generic quota exceeded exceptionclass
Describe the throttling result.class
An Exception that is thrown when a space quota is in violation. -
Uses of HBaseIOException in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
Thrown if Mutation'sDurability
is skip wal but table need replication.class
Reports a problem with a leaseclass
Thrown if request for nonexistent column family.class
Deprecated.since 0.99.0.static class
static class
static class
-
Uses of HBaseIOException in org.apache.hadoop.hbase.regionserver.storefiletracker
ModifierConstructorDescriptionModifyColumnFamilyStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, byte[] family, String dstSFT) protected
ModifyStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, String dstSFT) ModifyTableStoreFileTrackerProcedure
(MasterProcedureEnv env, TableName tableName, String dstSFT) -
Uses of HBaseIOException in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeClassDescriptionclass
Thrown when a failed append or sync on a WAL.class
Thrown whenWAL.sync()
timeout. -
Uses of HBaseIOException in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionprivate List<Pair<List<RegionInfo>,
List<ServerName>>> RSGroupBasedLoadBalancer.generateGroupAssignments
(List<RegionInfo> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) -
Uses of HBaseIOException in org.apache.hadoop.hbase.security
Modifier and TypeClassDescriptionclass
Exception thrown by access-related methods. -
Uses of HBaseIOException in org.apache.hadoop.hbase.security.visibility
-
Uses of HBaseIOException in org.apache.hadoop.hbase.snapshot
Modifier and TypeClassDescriptionclass
Exception thrown when the found snapshot info from the filesystem is not valid.class
Thrown when a snapshot could not be exported due to an error during the operation.class
General exception base class for when a snapshot fails.class
Thrown when a snapshot could not be restored due to a server-side error when restoring it.class
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.class
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.class
Thrown when a snapshot exists, but should not.class
Thrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expiredclass
Exception thrown when we get a request for a snapshot we don't recognize. -
Uses of HBaseIOException in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
Thrown when the lease was expected to be recovered, but the file can't be opened.