Uses of Class
org.apache.hadoop.hbase.HBaseIOException
Packages that use org.apache.hadoop.hbase.HBaseIOException
Package
Description
Provides HBase Client
Table of Contents
Provides implementations of
HFile and HFile
BlockCache.Tools to help define network clients and servers.
-
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbaseModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.CallDroppedExceptionReturned to the clients when their request was discarded due to server being overloaded.classorg.apache.hadoop.hbase.CallQueueTooBigExceptionReturned to clients when their request was dropped because the call queue was too big to accept a new call.classorg.apache.hadoop.hbase.ConcurrentTableModificationExceptionThrown when a table has been modified concurrentlyclassorg.apache.hadoop.hbase.DoNotRetryIOExceptionSubclass if exception is not meant to be retried: e.g.classorg.apache.hadoop.hbase.HBaseServerExceptionBase class for exceptions thrown by an HBase server.classorg.apache.hadoop.hbase.InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but made for an invalid family name.classorg.apache.hadoop.hbase.MasterNotRunningExceptionThrown if the master is not runningclassorg.apache.hadoop.hbase.NamespaceExistExceptionThrown when a namespace exists but should notclassorg.apache.hadoop.hbase.NamespaceNotFoundExceptionThrown when a namespace can not be locatedclassorg.apache.hadoop.hbase.NotAllMetaRegionsOnlineExceptionThrown when an operation requires the root and all meta regions to be onlineclassorg.apache.hadoop.hbase.PleaseHoldExceptionThis 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.classorg.apache.hadoop.hbase.PleaseRestartMasterExceptionThrown if the master requires restart.classorg.apache.hadoop.hbase.RegionExceptionThrown when something happens related to region handling.classorg.apache.hadoop.hbase.ReplicationPeerNotFoundExceptionThrown when a replication peer can not be foundclassorg.apache.hadoop.hbase.ServiceNotRunningExceptionclassorg.apache.hadoop.hbase.TableExistsExceptionThrown when a table exists but should not.classorg.apache.hadoop.hbase.TableInfoMissingExceptionFailed to find.tableinfofile under the table directory.classorg.apache.hadoop.hbase.TableNotDisabledExceptionThrown if a table should be offline but is not.classorg.apache.hadoop.hbase.TableNotEnabledExceptionThrown if a table should be enabled but is not.classorg.apache.hadoop.hbase.TableNotFoundExceptionThrown when a table cannot be located.classorg.apache.hadoop.hbase.UnknownRegionExceptionThrown when we are asked to operate on a region we know nothing about.classorg.apache.hadoop.hbase.UnknownScannerExceptionThrown if a region server is passed an unknown scanner ID. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.client
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.clientModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.client.DoNotRetryRegionExceptionSimilar to RegionException, but disables retries.classorg.apache.hadoop.hbase.client.NoServerForRegionExceptionThrown when no region server can be found for a regionclassorg.apache.hadoop.hbase.client.RegionOfflineExceptionThrown when a table can not be locatedclassorg.apache.hadoop.hbase.client.RowTooBigExceptionGets 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).classorg.apache.hadoop.hbase.client.WrongRowIOException -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.codec
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.codecModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.codec.CodecExceptionThrown when problems in the codec whether setup or context. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.coprocessor
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.coprocessorModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.coprocessor.CoprocessorExceptionThrown if a coprocessor encounters any exception. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.exceptions
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.exceptionsModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.exceptions.ConnectionClosedExceptionThrown when the connection is closedclassorg.apache.hadoop.hbase.exceptions.FailedSanityCheckExceptionException thrown if a mutation fails sanity checks.classorg.apache.hadoop.hbase.exceptions.MasterRegistryFetchExceptionException thrown when an master registry RPC fails in client.classorg.apache.hadoop.hbase.exceptions.MasterStoppedExceptionThrown when the master is stoppedclassorg.apache.hadoop.hbase.exceptions.MergeRegionExceptionThrown when something is wrong in trying to merge two regions.classorg.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextExceptionThrown by a RegionServer while doing next() calls on a ResultScanner.classorg.apache.hadoop.hbase.exceptions.RequestTooBigExceptionThrown when the size of the rpc request received by the server is too large.classorg.apache.hadoop.hbase.exceptions.ScannerResetExceptionThrown 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.classorg.apache.hadoop.hbase.exceptions.UnexpectedStateExceptionclassorg.apache.hadoop.hbase.exceptions.UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.favored
Methods in org.apache.hadoop.hbase.favored that throw org.apache.hadoop.hbase.HBaseIOException in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ServerNameFavoredNodeLoadBalancer.randomAssignment(org.apache.hadoop.hbase.client.RegionInfo regionInfo, List<org.apache.hadoop.hbase.ServerName> servers) FavoredNodeLoadBalancer.roundRobinAssignment(List<org.apache.hadoop.hbase.client.RegionInfo> regions, List<org.apache.hadoop.hbase.ServerName> servers) -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.io.hfile
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.io.hfileModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.io.hfile.CorruptHFileExceptionThis exception is thrown when attempts to read an HFile fail due to corruption or truncation issues. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.ipc
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.ipcModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ipc.BadAuthExceptionclassorg.apache.hadoop.hbase.ipc.CallCancelledExceptionClient side call cancelled.classorg.apache.hadoop.hbase.ipc.CallTimeoutExceptionClient-side call timeoutclassorg.apache.hadoop.hbase.ipc.CellScannerButNoCodecExceptionThrown if a cellscanner but no codec to encode it with.classorg.apache.hadoop.hbase.ipc.DecommissionedHostRejectedExceptionclassorg.apache.hadoop.hbase.ipc.EmptyServiceNameExceptionclassorg.apache.hadoop.hbase.ipc.FailedServerExceptionIndicates that we're trying to connect to a already known as dead server.classorg.apache.hadoop.hbase.ipc.FallbackDisallowedExceptionIndicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.classorg.apache.hadoop.hbase.ipc.FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.g.classorg.apache.hadoop.hbase.ipc.SecurityNotEnabledExceptionWill be thrown when server received a security preamble call for asking the server principal but security is not enabled for this server.classorg.apache.hadoop.hbase.ipc.ServerTooBusyExceptionThrow this in RPC call if there are too many pending requests for one region serverclassorg.apache.hadoop.hbase.ipc.StoppedRpcClientExceptionclassorg.apache.hadoop.hbase.ipc.UnknownServiceExceptionclassorg.apache.hadoop.hbase.ipc.UnsupportedCellCodecExceptionclassorg.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecExceptionclassorg.apache.hadoop.hbase.ipc.UnsupportedCryptoExceptionclassorg.apache.hadoop.hbase.ipc.WrongVersionException -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.master
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.masterModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.NoSuchProcedureException -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.quotas
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.quotasModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.quotas.QuotaExceededExceptionGeneric quota exceeded exceptionclassorg.apache.hadoop.hbase.quotas.RpcThrottlingExceptionDescribe the throttling result.classorg.apache.hadoop.hbase.quotas.SpaceLimitingExceptionAn Exception that is thrown when a space quota is in violation. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.regionserver
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.regionserverModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityExceptionThrown if Mutation'sDurabilityis skip wal but table need replication.classorg.apache.hadoop.hbase.regionserver.LeaseExceptionReports a problem with a leaseclassorg.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyExceptionThrown if request for nonexistent column family.classorg.apache.hadoop.hbase.regionserver.RowTooBigExceptionDeprecated.since 0.99.0.static classorg.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitExceptionstatic classorg.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitExceptionstatic classorg.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.regionserver.storefiletracker
Constructors in org.apache.hadoop.hbase.regionserver.storefiletracker that throw org.apache.hadoop.hbase.HBaseIOException in inModifierConstructorDescriptionModifyColumnFamilyStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, byte[] family, String dstSFT) protectedModifyStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT) ModifyTableStoreFileTrackerProcedure(org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv env, org.apache.hadoop.hbase.TableName tableName, String dstSFT) -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.regionserver.wal
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.regionserver.walModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.wal.DamagedWALExceptionThrown when a failed append or sync on a WAL.classorg.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOExceptionThrown whenWAL.sync()timeout. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.rsgroup
Methods in org.apache.hadoop.hbase.rsgroup that throw org.apache.hadoop.hbase.HBaseIOException in in -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.security
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.securityModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.security.AccessDeniedExceptionException thrown by access-related methods. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.snapshot
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.snapshotModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.snapshot.CorruptedSnapshotExceptionException thrown when the found snapshot info from the filesystem is not valid.classorg.apache.hadoop.hbase.snapshot.ExportSnapshotExceptionThrown when a snapshot could not be exported due to an error during the operation.classorg.apache.hadoop.hbase.snapshot.HBaseSnapshotExceptionGeneral exception base class for when a snapshot fails.classorg.apache.hadoop.hbase.snapshot.RestoreSnapshotExceptionThrown when a snapshot could not be restored due to a server-side error when restoring it.classorg.apache.hadoop.hbase.snapshot.SnapshotCreationExceptionThrown when a snapshot could not be created due to a server-side error when taking the snapshot.classorg.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistExceptionThrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.classorg.apache.hadoop.hbase.snapshot.SnapshotExistsExceptionThrown when a snapshot exists, but should not.classorg.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredExceptionThrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expiredclassorg.apache.hadoop.hbase.snapshot.UnknownSnapshotExceptionException thrown when we get a request for a snapshot we don't recognize. -
Uses of org.apache.hadoop.hbase.HBaseIOException in org.apache.hadoop.hbase.util
Subclasses of org.apache.hadoop.hbase.HBaseIOException in in org.apache.hadoop.hbase.utilModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.util.LeaseNotRecoveredExceptionThrown when the lease was expected to be recovered, but the file can't be opened.