Uses of Class
org.apache.hadoop.hbase.DoNotRetryIOException

Packages that use org.apache.hadoop.hbase.DoNotRetryIOException
  • Uses of org.apache.hadoop.hbase.DoNotRetryIOException in org.apache.hadoop.hbase

    Subclasses of org.apache.hadoop.hbase.DoNotRetryIOException in in org.apache.hadoop.hbase
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ConcurrentTableModificationException
    Thrown when a table has been modified concurrently
    class 
    org.apache.hadoop.hbase.InvalidFamilyOperationException
    Thrown if a request is table schema modification is requested but made for an invalid family name.
    class 
    org.apache.hadoop.hbase.NamespaceExistException
    Thrown when a namespace exists but should not
    class 
    org.apache.hadoop.hbase.NamespaceNotFoundException
    Thrown when a namespace can not be located
    class 
    org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
    Thrown when an operation requires the root and all meta regions to be online
    class 
    org.apache.hadoop.hbase.ReplicationPeerNotFoundException
    Thrown when a replication peer can not be found
    class 
    org.apache.hadoop.hbase.TableExistsException
    Thrown when a table exists but should not.
    class 
    org.apache.hadoop.hbase.TableNotDisabledException
    Thrown if a table should be offline but is not.
    class 
    org.apache.hadoop.hbase.TableNotEnabledException
    Thrown if a table should be enabled but is not.
    class 
    org.apache.hadoop.hbase.TableNotFoundException
    Thrown when a table cannot be located.
    class 
    org.apache.hadoop.hbase.UnknownRegionException
    Thrown when we are asked to operate on a region we know nothing about.
    class 
    org.apache.hadoop.hbase.UnknownScannerException
    Thrown 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.client
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.client.DoNotRetryRegionException
    Similar to RegionException, but disables retries.
    class 
    org.apache.hadoop.hbase.client.NoServerForRegionException
    Thrown when no region server can be found for a region
    class 
    org.apache.hadoop.hbase.client.OperationTimeoutExceededException
    Thrown when a batch operation exceeds the operation timeout
    class 
    org.apache.hadoop.hbase.client.RowTooBigException
    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 that throw org.apache.hadoop.hbase.DoNotRetryIOException in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Result
    RpcRetryingCallerWithReadReplicas.call(int operationTimeout)
    Algo: - we put the query into the execution pool.
    static org.apache.hadoop.hbase.RegionLocations
    RegionAdminServiceCallable.getRegionLocations(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean useCache, int replicaId)
     
  • 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.coprocessor
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.coprocessor.CoprocessorException
    Thrown 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.exceptions
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
    Exception thrown if a mutation fails sanity checks.
    class 
    org.apache.hadoop.hbase.exceptions.MasterStoppedException
    Thrown when the master is stopped
    class 
    org.apache.hadoop.hbase.exceptions.MergeRegionException
    Thrown when something is wrong in trying to merge two regions.
    class 
    org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
    Thrown by a RegionServer while doing next() calls on a ResultScanner.
    class 
    org.apache.hadoop.hbase.exceptions.RequestTooBigException
    Thrown when the size of the rpc request received by the server is too large.
    class 
    org.apache.hadoop.hbase.exceptions.ScannerResetException
    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 
    org.apache.hadoop.hbase.exceptions.UnknownProtocolException
    An 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.hfile
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.io.hfile.CorruptHFileException
    This 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.ipc
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ipc.BadAuthException
     
    class 
    org.apache.hadoop.hbase.ipc.EmptyServiceNameException
     
    class 
    org.apache.hadoop.hbase.ipc.FatalConnectionException
    Thrown when server finds fatal issue w/ connection setup: e.g.
    class 
    org.apache.hadoop.hbase.ipc.ServerTooBusyException
    Throw this in RPC call if there are too many pending requests for one region server
    class 
    org.apache.hadoop.hbase.ipc.StoppedRpcClientException
     
    class 
    org.apache.hadoop.hbase.ipc.UnknownServiceException
     
    class 
    org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
     
    class 
    org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
     
    class 
    org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
     
    class 
    org.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.quotas
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.quotas.QuotaExceededException
    Generic quota exceeded exception
    class 
    org.apache.hadoop.hbase.quotas.SpaceLimitingException
    An Exception that is thrown when a space quota is in violation.
    class 
    org.apache.hadoop.hbase.quotas.ThrottlingException
    Deprecated.
    replaced by RpcThrottlingException since hbase-2.0.0.
  • 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.regionserver
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.LeaseException
    Reports a problem with a lease
    class 
    org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
    Thrown if request for nonexistent column family.
    class 
    org.apache.hadoop.hbase.regionserver.RowTooBigException
    Deprecated.
    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.security
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.security.AccessDeniedException
    Exception 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 in
    Modifier and Type
    Method
    Description
    static String
    ProtobufUtil.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.snapshot
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
    Exception thrown when the found snapshot info from the filesystem is not valid.
    class 
    org.apache.hadoop.hbase.snapshot.ExportSnapshotException
    Thrown when a snapshot could not be exported due to an error during the operation.
    class 
    org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
    General exception base class for when a snapshot fails.
    class 
    org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
    Thrown when a snapshot could not be restored due to a server-side error when restoring it.
    class 
    org.apache.hadoop.hbase.snapshot.SnapshotCreationException
    Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
    class 
    org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
    Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
    class 
    org.apache.hadoop.hbase.snapshot.SnapshotExistsException
    Thrown when a snapshot exists, but should not.
    class 
    org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
    Thrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expired
    class 
    org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
    Exception thrown when we get a request for a snapshot we don't recognize.