Uses of Class
org.apache.hadoop.hbase.DoNotRetryIOException
Packages that use org.apache.hadoop.hbase.DoNotRetryIOException
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.DoNotRetryIOException in org.apache.hadoop.hbase
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException in in org.apache.hadoop.hbaseModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ConcurrentTableModificationExceptionThrown when a table has been modified concurrentlyclassorg.apache.hadoop.hbase.InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but made for an invalid family name.classorg.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.ReplicationPeerNotFoundExceptionThrown when a replication peer can not be foundclassorg.apache.hadoop.hbase.TableExistsExceptionThrown when a table exists but should not.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.DoNotRetryIOException in org.apache.hadoop.hbase.client
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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.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). -
Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase.coprocessor
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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.DoNotRetryIOException in org.apache.hadoop.hbase.exceptions
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException in in org.apache.hadoop.hbase.exceptionsModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.exceptions.FailedSanityCheckExceptionException thrown if a mutation fails sanity checks.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.UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving. -
Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase.io.hfile
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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.DoNotRetryIOException in org.apache.hadoop.hbase.ipc
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException in in org.apache.hadoop.hbase.ipcModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ipc.BadAuthExceptionclassorg.apache.hadoop.hbase.ipc.EmptyServiceNameExceptionclassorg.apache.hadoop.hbase.ipc.FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.g.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.DoNotRetryIOException in org.apache.hadoop.hbase.quotas
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException in in org.apache.hadoop.hbase.quotasModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.quotas.QuotaExceededExceptionGeneric quota exceeded exceptionclassorg.apache.hadoop.hbase.quotas.SpaceLimitingExceptionAn Exception that is thrown when a space quota is in violation. -
Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase.regionserver
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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. -
Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase.security
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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.DoNotRetryIOException in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf that throw org.apache.hadoop.hbase.DoNotRetryIOException in inModifier and TypeMethodDescriptionstatic StringProtobufUtil.getRegionEncodedName(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier) Find the HRegion encoded name based on a region specifier -
Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase.snapshot
Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException 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.