Uses of Class
org.apache.hadoop.hbase.DoNotRetryIOException
Packages that use DoNotRetryIOException
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 DoNotRetryIOException in org.apache.hadoop.hbase
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbaseModifier and TypeClassDescriptionclass
Thrown when a table has been modified concurrentlyclass
Thrown if a request is table schema modification is requested but made for an invalid family name.class
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
Thrown when a replication peer can not be foundclass
Thrown when a table exists but should not.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 DoNotRetryIOException in org.apache.hadoop.hbase.client
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.clientModifier and TypeClassDescriptionprivate static class
LikeConnectionClosedException
but thrown from the checkClosed call which looks at the local this.closed flag.class
Similar to RegionException, but disables retries.class
Thrown when no region server can be found for a regionclass
Thrown when a batch operation exceeds the operation timeoutclass
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).Methods in org.apache.hadoop.hbase.client with parameters of type DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate void
ClientScanner.handleScanError
(DoNotRetryIOException e, org.apache.commons.lang3.mutable.MutableBoolean retryAfterOutOfOrderException, int retriesLeft) Methods in org.apache.hadoop.hbase.client that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionRpcRetryingCallerWithReadReplicas.call
(int operationTimeout) Algo: - we put the query into the execution pool.static RegionLocations
RegionAdminServiceCallable.getRegionLocations
(ClusterConnection connection, TableName tableName, byte[] row, boolean useCache, int replicaId) (package private) static RegionLocations
RpcRetryingCallerWithReadReplicas.getRegionLocations
(boolean useCache, int replicaId, ClusterConnection cConnection, TableName tableName, byte[] row) private void
ClientScanner.handleScanError
(DoNotRetryIOException e, org.apache.commons.lang3.mutable.MutableBoolean retryAfterOutOfOrderException, int retriesLeft) (package private) static void
RpcRetryingCallerWithReadReplicas.throwEnrichedException
(ExecutionException e, int retries) Extract the real exception from the ExecutionException, and throws what makes more sense.(package private) static Throwable
RpcRetryingCallerImpl.translateException
(Throwable t) Get the good or the remote exception if any, throws the DoNotRetryIOException. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.constraint
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.constraintModifier and TypeClassDescriptionclass
Exception that a user defined constraint throws on failure of aPut
. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.coprocessor
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.coprocessorModifier and TypeClassDescriptionclass
Thrown if a coprocessor encounters any exception. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.exceptions
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.exceptionsModifier and TypeClassDescriptionclass
Exception thrown if a mutation fails sanity checks.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
An error requesting an RPC protocol that the server is not serving. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.fs
Methods in org.apache.hadoop.hbase.fs that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate static boolean
ErasureCodingUtils.checkPolicyMatch
(Object policyInfo, String requestedPolicy) private static org.apache.hadoop.hdfs.DistributedFileSystem
ErasureCodingUtils.getDfs
(org.apache.hadoop.fs.FileSystem fs) -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.io.hfile
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.io.hfileModifier and TypeClassDescriptionclass
This exception is thrown when attempts to read an HFile fail due to corruption or truncation issues. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.ipc
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.ipcModifier and TypeClassDescriptionclass
class
class
Thrown when server finds fatal issue w/ connection setup: e.g.class
Throw this in RPC call if there are too many pending requests for one region serverclass
class
class
class
class
class
-
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.master.replication
Methods in org.apache.hadoop.hbase.master.replication that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate void
ReplicationPeerManager.checkClusterKey
(String clusterKey) private void
ReplicationPeerManager.checkConfiguredWALEntryFilters
(ReplicationPeerConfig peerConfig) private void
ReplicationPeerManager.checkNamespacesAndTableCfsConfigConflict
(Set<String> namespaces, Map<TableName, ? extends Collection<String>> tableCfs) Set a namespace in the peer config means that all tables in this namespace will be replicated to the peer cluster.private void
ReplicationPeerManager.checkPeerConfig
(ReplicationPeerConfig peerConfig) private ReplicationPeerDescription
ReplicationPeerManager.checkPeerExists
(String peerId) private void
ReplicationPeerManager.checkQueuesDeleted
(String peerId) private void
ReplicationPeerManager.checkSameClusterKey
(String clusterKey) (package private) void
ReplicationPeerManager.preAddPeer
(String peerId, ReplicationPeerConfig peerConfig) (package private) void
ReplicationPeerManager.preDisablePeer
(String peerId) (package private) void
ReplicationPeerManager.preEnablePeer
(String peerId) (package private) ReplicationPeerConfig
ReplicationPeerManager.preRemovePeer
(String peerId) (package private) ReplicationPeerDescription
ReplicationPeerManager.preUpdatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Return the old peer description. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.quotas
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.quotasModifier and TypeClassDescriptionclass
Generic quota exceeded exceptionclass
An Exception that is thrown when a space quota is in violation.class
Deprecated. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.regionserver
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.regionserverModifier and TypeClassDescriptionclass
Reports a problem with a leaseclass
Thrown if request for nonexistent column family.class
Deprecated.since 0.99.0.Methods in org.apache.hadoop.hbase.regionserver that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate void
HRegion.checkMutationType
(Mutation mutation) private void
private static long
HRegion.MutationBatchOperation.getLongValue
(Cell cell) Returns Get the long out of the passed in Cell -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.regionserver.storefiletracker
Methods in org.apache.hadoop.hbase.regionserver.storefiletracker that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate void
ModifyStoreFileTrackerProcedure.checkDstSFT
(String dstSFT) -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.rsgroup
Methods in org.apache.hadoop.hbase.rsgroup that throw DoNotRetryIOExceptionModifier and TypeMethodDescriptionprivate RSGroupInfo
RSGroupInfoManagerImpl.getRSGroupInfo
(String groupName) -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.security
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.securityModifier and TypeClassDescriptionclass
Exception thrown by access-related methods. -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.security.visibility
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.security.visibility -
Uses of DoNotRetryIOException in org.apache.hadoop.hbase.snapshot
Subclasses of DoNotRetryIOException in org.apache.hadoop.hbase.snapshotModifier 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.
RpcThrottlingException
since hbase-2.0.0.