Modifier and Type | Interface and Description |
---|---|
interface |
Cell
The unit of storage in HBase consisting of the following fields:
|
class |
CellUtil
Utility methods helpful slinging
Cell instances. |
class |
ClockOutOfSyncException
This exception is thrown by the master when a region server clock skew is
too high.
|
class |
ClusterStatus
Status information on the HBase cluster.
|
class |
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
class |
DroppedSnapshotException
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
|
class |
HBaseConfiguration
Adds HBase configuration files to a Configuration
|
class |
HBaseInterfaceAudience
This class defines constants for different classes of hbase limited private apis
|
class |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
class |
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
class |
HConstants
HConstants holds a bunch of HBase-related constants
|
class |
HRegionInfo
Information about a region.
|
class |
HRegionLocation
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
|
class |
HTableDescriptor
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table,
-ROOT- or
hbase:meta , if the table is read only, the maximum size of the memstore,
when the region split should occur, coprocessors associated with it etc... |
class |
InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
class |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
class |
LocalHBaseCluster
This class creates a single process HBase cluster.
|
class |
MasterNotRunningException
Thrown if the master is not running
|
class |
NamespaceDescriptor
Namespace POJO class.
|
static class |
NamespaceDescriptor.Builder |
class |
NamespaceExistException
Thrown when a namespace exists but should not
|
class |
NamespaceNotFoundException
Thrown when a namespace can not be located
|
class |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
class |
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not
serving.
|
class |
PleaseHoldException
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 |
ProcedureInfo
Procedure information
|
class |
RegionException
Thrown when something happens related to region handling.
|
class |
RegionLoad
Encapsulates per-region load metrics.
|
class |
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
|
class |
ServerLoad
This class is used for exporting current state of load on a RegionServer.
|
class |
ServerName
Instance of an HBase ServerName.
|
class |
TableExistsException
Thrown when a table exists but should not
|
class |
TableInfoMissingException
Failed to find .tableinfo file under table dir
|
class |
TableName
Immutable POJO class for representing a table name.
|
class |
TableNotDisabledException
Thrown if a table should be offline but is not
|
class |
TableNotEnabledException
Thrown if a table should be enabled but is not
|
class |
TableNotFoundException
Thrown when a table can not be located
|
class |
UnknownRegionException
Thrown when we are asked to operate on a region we know nothing about.
|
class |
UnknownScannerException
Thrown if a region server is passed an unknown scanner id.
|
class |
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Modifier and Type | Class and Description |
---|---|
class |
InterfaceAudience
Annotation to inform users of a package, class or method's intended audience.
|
class |
InterfaceStability
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Admin
The administrative API for HBase.
|
class |
Append
Performs Append operations on a single row.
|
interface |
Attributes |
interface |
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for
batched, asynchronous puts. |
static interface |
BufferedMutator.ExceptionListener
Listens for asynchronous exceptions on a
BufferedMutator . |
class |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
interface |
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
class |
ConnectionFactory
A non-instantiable class that manages creation of
Connection s. |
class |
Consistency
Consistency defines the expected consistency level for an operation.
|
class |
Delete
Used to perform Delete operations on a single row.
|
class |
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
class |
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
class |
Get
Used to perform Get operations on a single row.
|
interface |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
class |
HConnectionManager
Deprecated.
Please use ConnectionFactory instead
|
class |
HTableFactory
Deprecated.
as of 0.98.1. See
HConnectionManager.createConnection(Configuration) . |
interface |
HTableInterfaceFactory
Deprecated.
in favor of
ConnectionFactory and Connection . |
class |
HTableMultiplexer
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
|
static class |
HTableMultiplexer.HTableMultiplexerStatus
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
|
class |
Increment
Used to perform Increment operations on a single row.
|
class |
IsolationLevel
Specify Isolation levels in Scan operations.
|
class |
Mutation |
class |
NoServerForRegionException
Thrown when no region server can be found for a region
|
class |
Operation
Superclass for any type that maps to a potentially application-level query.
|
class |
OperationWithAttributes |
class |
Put
Used to perform Put operations for a single row.
|
class |
Query |
interface |
RegionLocator
Used to view region location information for a single HBase table.
|
class |
RegionOfflineException
Thrown when a table can not be located
|
class |
Result
|
interface |
ResultScanner
Interface for client-side scanning.
|
class |
RetriesExhaustedException
Exception thrown by HTable methods when an attempt to do something (like
commit changes) fails after a bunch of retries.
|
class |
RetriesExhaustedWithDetailsException
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers. |
interface |
Row
Has a row.
|
class |
RowMutations
Performs multiple mutations atomically on a single row.
|
class |
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).
|
class |
Scan
Used to perform Scan operations.
|
class |
ScannerTimeoutException
Thrown when a scanner has timed out.
|
interface |
Table
Used to communicate with a single HBase table.
|
class |
TableSnapshotScanner
A Scanner which performs a scan over snapshot files.
|
class |
UnmodifyableHTableDescriptor
Read-only table descriptor.
|
class |
WrongRowIOException |
Modifier and Type | Interface and Description |
---|---|
interface |
ClientBackoffPolicy
Configurable policy for the amount of time a client should wait for a new request to the
server when given the server load statistics.
|
class |
ExponentialClientBackoffPolicy
Simple exponential backoff policy on for the client that uses a percent^4 times the
max backoff to generate the backoff time.
|
Modifier and Type | Class and Description |
---|---|
class |
Batch
A collection of interfaces and utilities used for interacting with custom RPC
interfaces exposed by Coprocessors.
|
static interface |
Batch.Call<T,R>
Defines a unit of work to be executed.
|
static interface |
Batch.Callback<R>
Defines a generic callback to be triggered for each
Batch.Call.call(Object)
result. |
class |
DoubleColumnInterpreter
a concrete column interpreter implementation.
|
Modifier and Type | Class and Description |
---|---|
class |
ScanMetrics
Provides client-side metrics related to scan operations.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicationAdmin
This class provides the administrative interface to HBase cluster
replication.
|
Modifier and Type | Class and Description |
---|---|
class |
CoprocessorException
Thrown if a coprocessor encounters any exception.
|
Modifier and Type | Class and Description |
---|---|
class |
ForeignException
A ForeignException is an exception from another thread or process.
|
class |
TimeoutException
Exception for timeout of a task.
|
Modifier and Type | Class and Description |
---|---|
class |
ConnectionClosingException
Thrown when the client believes that we are trying to communicate to has
been repeatedly unresponsive for a while.
|
class |
FailedSanityCheckException
Exception thrown if a mutation fails sanity checks.
|
class |
LockTimeoutException
Thrown when there is a timeout when trying to acquire a lock
|
class |
MergeRegionException
Thrown when something is wrong in trying to merge two regions.
|
class |
OperationConflictException
The exception that is thrown if there's duplicate execution of non-idempotent operation.
|
class |
PreemptiveFastFailException
Thrown when the client believes that we are trying to communicate to has
been repeatedly unresponsive for a while.
|
class |
RegionInRecoveryException
Thrown when a read request issued against a region which is in recovering state.
|
class |
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 |
UnknownProtocolException
An error requesting an RPC protocol that the server is not serving.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryComparator
A binary comparator which lexicographically compares against the specified
byte array using
Bytes.compareTo(byte[], byte[]) . |
class |
BinaryPrefixComparator
A comparator which compares against a specified byte array, but only compares
up to the length of this byte array.
|
class |
BitComparator
A bit comparator which performs the specified bitwise operation on each of the bytes
with the specified byte array.
|
static class |
BitComparator.BitwiseOp
Bit operators.
|
class |
ByteArrayComparable
Base class for byte array comparators
|
class |
ColumnCountGetFilter
Simple filter that returns first N columns on row only.
|
class |
ColumnPaginationFilter
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
|
class |
ColumnPrefixFilter
This filter is used for selecting only those keys with columns that matches
a particular prefix.
|
class |
ColumnRangeFilter
This filter is used for selecting only those keys with columns that are
between minColumn to maxColumn.
|
class |
CompareFilter
This is a generic filter to be used to filter by comparison.
|
static class |
CompareFilter.CompareOp
Comparison operators.
|
class |
DependentColumnFilter
A filter for adding inter-column timestamp matching
Only cells with a correspondingly timestamped entry in
the target column will be retained
Not compatible with Scan.setBatch as operations need
full rows for correct filtering
|
class |
FamilyFilter
This filter is used to filter based on the column family.
|
class |
Filter
Interface for row and column filters directly applied within the regionserver.
|
static class |
Filter.ReturnCode
Return codes for filterValue().
|
class |
FilterList
Implementation of
Filter that represents an ordered List of Filters
which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL
(AND ) or FilterList.Operator.MUST_PASS_ONE (OR ). |
static class |
FilterList.Operator
set operator
|
class |
FirstKeyOnlyFilter
A filter that will only return the first KV from each row.
|
class |
FirstKeyValueMatchingQualifiersFilter
The filter looks for the given columns in KeyValue.
|
class |
FuzzyRowFilter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
|
class |
InclusiveStopFilter
A Filter that stops after the given row.
|
class |
IncompatibleFilterException
Used to indicate a filter incompatibility
|
class |
InvalidRowFilterException
Used to indicate an invalid RowFilter.
|
class |
KeyOnlyFilter
A filter that will only return the key component of each KV (the value will
be rewritten as empty).
|
class |
LongComparator
A long comparator which numerical compares against the specified byte array
|
class |
MultipleColumnPrefixFilter
This filter is used for selecting only those keys with columns that matches
a particular prefix.
|
class |
MultiRowRangeFilter
Filter to support scan multiple row key ranges.
|
static class |
MultiRowRangeFilter.RowRange |
class |
NullComparator
A binary comparator which lexicographically compares against the specified
byte array using
Bytes.compareTo(byte[], byte[]) . |
class |
PageFilter
Implementation of Filter interface that limits results to a specific page
size.
|
class |
ParseConstants
ParseConstants holds a bunch of constants related to parsing Filter Strings
Used by
ParseFilter |
class |
ParseFilter
This class allows a user to specify a filter via a string
The string is parsed using the methods of this class and
a filter object is constructed.
|
class |
PrefixFilter
Pass results that have same row prefix.
|
class |
QualifierFilter
This filter is used to filter based on the column qualifier.
|
class |
RandomRowFilter
A filter that includes rows based on a chance.
|
class |
RegexStringComparator
This comparator is for use with
CompareFilter implementations, such
as RowFilter , QualifierFilter , and ValueFilter , for
filtering based on the value of a given column. |
static class |
RegexStringComparator.EngineType
Engine implementation type (default=JAVA)
|
class |
RowFilter
This filter is used to filter based on the key.
|
class |
SingleColumnValueExcludeFilter
A
Filter that checks a single column value, but does not emit the
tested column. |
class |
SingleColumnValueFilter
This filter is used to filter cells based on value.
|
class |
SkipFilter
A wrapper filter that filters an entire row if any of the Cell checks do
not pass.
|
class |
SubstringComparator
This comparator is for use with SingleColumnValueFilter, for filtering based on
the value of a given column.
|
class |
TimestampsFilter
Filter that returns only cells whose timestamp (version) is
in the specified list of timestamps (versions).
|
class |
ValueFilter
This filter is used to filter based on column value.
|
class |
WhileMatchFilter
A wrapper filter that returns true from
WhileMatchFilter.filterAllRemaining() as soon
as the wrapped filters Filter.filterRowKey(byte[], int, int) ,
Filter.filterKeyValue(org.apache.hadoop.hbase.Cell) ,
Filter.filterRow() or
Filter.filterAllRemaining() methods
returns true. |
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferOutputStream
Not thread safe!
|
class |
ImmutableBytesWritable
A byte sequence that is usable as a key or value.
|
static class |
ImmutableBytesWritable.Comparator
A Comparator optimized for ImmutableBytesWritable.
|
class |
TimeRange
Represents an interval of version timestamps.
|
Modifier and Type | Class and Description |
---|---|
static class |
Compression.Algorithm
Compression algorithms.
|
Modifier and Type | Class and Description |
---|---|
class |
Cipher
A common interface for a cryptographic algorithm.
|
interface |
CipherProvider
An CipherProvider contributes support for various cryptographic
Ciphers.
|
class |
Context
Crypto context.
|
interface |
Decryptor
Decryptors apply a cipher to an InputStream to recover plaintext.
|
class |
DefaultCipherProvider
The default cipher provider.
|
class |
Encryption
A facade for encryption algorithms and related support.
|
static class |
Encryption.Context
Crypto context
|
interface |
Encryptor
Encryptors apply a cipher to an OutputStream to produce ciphertext.
|
interface |
KeyProvider
KeyProvider is a interface to abstract the different methods of retrieving
key material from key storage such as Java key store.
|
class |
KeyStoreKeyProvider
A basic KeyProvider that can resolve keys from a protected KeyStore file
on the local filesystem.
|
Modifier and Type | Class and Description |
---|---|
class |
DataBlockEncoding
Provide access to all data block encoding algorithms.
|
Modifier and Type | Class and Description |
---|---|
class |
BadAuthException |
class |
CallerDisconnectedException
Exception indicating that the remote host making this IPC lost its
IPC connection.
|
class |
CallTimeoutException
Client-side call timeout
|
class |
CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
call coprocessor endpoint
Service s. |
class |
FailedServerException
Indicates that we're trying to connect to a already known as dead server.
|
class |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
class |
RemoteWithExtrasException
A
RemoteException with some extra information. |
class |
ServerNotRunningYetException |
class |
StoppedRpcClientException |
class |
UnsupportedCellCodecException |
class |
UnsupportedCompressionCodecException |
class |
WrongVersionException |
Modifier and Type | Class and Description |
---|---|
class |
GroupingTableMap
Extract grouping columns from input record
|
class |
HRegionPartitioner<K2,V2>
This is used to partition the output keys into groups of keys.
|
class |
IdentityTableMap
Pass the given key and record as-is to reduce
|
class |
IdentityTableReduce
Write to table each key, record pair
|
class |
RowCounter
A job with a map to count rows.
|
class |
TableInputFormat
Convert HBase tabular data into a format that is consumable by Map/Reduce.
|
class |
TableInputFormatBase
A Base for
TableInputFormat s. |
interface |
TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V>
Scan an HBase table to sort by a specified sort column.
|
class |
TableMapReduceUtil
Utility for
TableMap and TableReduce |
class |
TableOutputFormat
Convert Map/Reduce output and write it to an HBase table
|
class |
TableRecordReader
Iterate over an HBase table data, return (Text, RowResult) pairs
|
class |
TableRecordReaderImpl
Iterate over an HBase table data, return (Text, RowResult) pairs
|
interface |
TableReduce<K extends org.apache.hadoop.io.WritableComparable,V>
Write a table, sorting by the input key
|
class |
TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
|
class |
TableSplit
A table split corresponds to a key range [low, high)
|
Modifier and Type | Class and Description |
---|---|
class |
CellCounter
A job with a a map and reduce phase to count cells in a table.
|
class |
CellCreator
Facade to create Cells for HFileOutputFormat.
|
class |
CopyTable
Tool used to copy a table to another one which can be on a different setup.
|
class |
Export
Export an HBase table.
|
class |
GroupingTableMapper
Extract grouping columns from input record.
|
class |
HFileOutputFormat
Deprecated.
use
HFileOutputFormat2 instead. |
class |
HFileOutputFormat2
Writes HFiles.
|
class |
HLogInputFormat
Deprecated.
use
WALInputFormat |
class |
HRegionPartitioner<KEY,VALUE>
This is used to partition the output keys into groups of keys.
|
class |
IdentityTableMapper
Pass the given key and record as-is to the reduce phase.
|
class |
IdentityTableReducer
|
class |
Import
Import data written by
Export . |
class |
ImportTsv
Tool to import data from a TSV file.
|
class |
KeyValueSortReducer
Emits sorted KeyValues.
|
class |
LoadIncrementalHFiles
Tool to load the output of HFileOutputFormat into an existing table.
|
class |
MultiTableInputFormat
Convert HBase tabular data from multiple scanners into a format that
is consumable by Map/Reduce.
|
class |
MultiTableInputFormatBase
A base for
MultiTableInputFormat s. |
class |
MultiTableOutputFormat
Hadoop output format that writes to one or more HBase tables.
|
class |
PutCombiner<K>
Combine Puts.
|
class |
PutSortReducer
Emits sorted Puts.
|
class |
RowCounter
A job with a just a map phase to count rows.
|
class |
SimpleTotalOrderPartitioner<VALUE>
A partitioner that takes start and end keys and uses bigdecimal to figure
which reduce a key belongs to.
|
class |
TableInputFormat
Convert HBase tabular data into a format that is consumable by Map/Reduce.
|
class |
TableInputFormatBase
A base for
TableInputFormat s. |
class |
TableMapper<KEYOUT,VALUEOUT>
Extends the base
Mapper class to add the required input key
and value classes. |
class |
TableMapReduceUtil
Utility for
TableMapper and TableReducer |
class |
TableOutputCommitter
Small committer class that does not do anything.
|
class |
TableOutputFormat<KEY>
Convert Map/Reduce output and write it to an HBase table.
|
class |
TableRecordReader
Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
pairs.
|
class |
TableRecordReaderImpl
Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
pairs.
|
class |
TableReducer<KEYIN,VALUEIN,KEYOUT>
Extends the basic
Reducer class to add the required key and
value input/output classes. |
class |
TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
|
class |
TableSplit
A table split corresponds to a key range (low, high) and an optional scanner.
|
class |
TextSortReducer
Emits Sorted KeyValues.
|
class |
TsvImporterMapper
Write table content out to files in hdfs.
|
class |
TsvImporterTextMapper
Write table content out to map output files.
|
interface |
VisibilityExpressionResolver
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
|
class |
WALInputFormat
Simple
InputFormat for WAL files. |
class |
WALPlayer
A tool to replay WAL files as a M/R job.
|
Modifier and Type | Class and Description |
---|---|
class |
QuotaExceededException
Generic quota exceeded exception
|
class |
QuotaFilter
Filter to use to filter the QuotaRetriever results.
|
class |
QuotaRetriever
Scanner to iterate over the quota settings.
|
class |
QuotaScope
Describe the Scope of the quota rules.
|
class |
QuotaSettings |
class |
QuotaSettingsFactory |
class |
QuotaType
Describe the Quota Type.
|
class |
ThrottleType
Describe the Throttle Type.
|
class |
ThrottlingException
Describe the throttling result.
|
static class |
ThrottlingException.Type |
Modifier and Type | Class and Description |
---|---|
class |
BloomType |
class |
LeaseException
Reports a problem with a lease
|
class |
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
class |
RegionAlreadyInTransitionException
This exception is thrown when a region server is asked to open or close
a region but it's already processing it
|
class |
RegionServerAbortedException
Thrown by the region server when it is aborting.
|
class |
RegionServerRunningException
Thrown if the region server log directory exists (which indicates another
region server is running at the same address)
|
class |
RegionServerStoppedException
Thrown by the region server when it is in shutting down state.
|
class |
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).
|
class |
WrongRegionException
Thrown when a request contains a key which is not part of this region
|
Modifier and Type | Class and Description |
---|---|
class |
FailedLogCloseException
Thrown when we fail close of the write-ahead-log file.
|
class |
FailedSyncBeforeLogCloseException
Thrown when we fail close of the write-ahead-log file.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicationException
An HBase Replication exception.
|
class |
ReplicationPeerConfig
A configuration for the replication peer cluster.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Constants
Common constants for org.apache.hadoop.hbase.rest
|
Modifier and Type | Class and Description |
---|---|
class |
Client
A wrapper around HttpClient which provides some useful function and
semantics for interacting with the REST gateway.
|
class |
Cluster
A list of 'host:port' addresses of HTTP servers operating as a single
entity, for example multiple redundant web service gateways.
|
class |
RemoteAdmin |
class |
RemoteHTable
HTable interface to remote tables accessed via REST gateway
|
class |
Response
The HTTP result code, response headers, and body of a HTTP response.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessDeniedException
Exception thrown by access-related methods.
|
class |
User
Wrapper to abstract out usage of user and group information in HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessControlClient
Utility client for doing access control admin operations.
|
interface |
AccessControlConstants |
class |
Permission
Base permissions instance representing the ability to perform a given set
of actions.
|
static class |
Permission.Action |
Modifier and Type | Class and Description |
---|---|
class |
TokenUtil
Utility methods for obtaining authentication tokens.
|
Modifier and Type | Class and Description |
---|---|
class |
Authorizations
This class contains visibility labels associated with a Scan/Get deciding which all labeled data
current scan/get can access.
|
class |
CellVisibility
This contains a visibility expression which can be associated with a cell.
|
class |
InvalidLabelException |
class |
LabelAlreadyExistsException |
interface |
ScanLabelGenerator
This would be the interface which would be used add labels to the RPC context
and this would be stored against the UGI.
|
class |
VisibilityClient
Utility client for doing visibility labels admin operations.
|
class |
VisibilityControllerNotReadyException |
interface |
VisibilityExpEvaluator
During the read (ie.
|
interface |
VisibilityLabelService
The interface which deals with visibility labels and user auths admin service as well as the cell
visibility expression storage part and read time evaluation.
|
Modifier and Type | Class and Description |
---|---|
class |
CorruptedSnapshotException
Exception thrown when the found snapshot info from the filesystem is not valid
|
class |
ExportSnapshot
Export the specified snapshot to a given FileSystem.
|
class |
ExportSnapshotException
Thrown when a snapshot could not be exported due to an error during the operation.
|
class |
HBaseSnapshotException
General exception base class for when a snapshot fails
|
class |
RestoreSnapshotException
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
|
class |
SnapshotCreationException
Thrown when a snapshot could not be created due to a server-side error when
taking the snapshot.
|
class |
SnapshotDoesNotExistException
Thrown when the server is looking for a snapshot but can't find the snapshot on the filesystem
|
class |
SnapshotExistsException
Thrown when a snapshot exists but should not
|
class |
SnapshotInfo
Tool for dumping snapshot information.
|
class |
TablePartiallyOpenException
Thrown if a table should be online/offline but is partially open
|
class |
UnknownSnapshotException
Exception thrown when we get a request for a snapshot we don't recognize.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataType<T>
DataType is the base class for all HBase data types. |
class |
FixedLengthWrapper<T>
Wraps an existing
DataType implementation as a fixed-length
version of itself. |
class |
OrderedBlob
A
byte[] of variable-length. |
class |
OrderedBlobVar
An alternative to
OrderedBlob for use by Struct fields that
do not terminate the fields list. |
class |
OrderedBytesBase<T>
Base class for data types backed by the
OrderedBytes encoding
implementations. |
class |
OrderedFloat32
A
float of 32-bits using a fixed-length encoding. |
class |
OrderedFloat64
A
double of 64-bits using a fixed-length encoding. |
class |
OrderedInt16
A
short of 16-bits using a fixed-length encoding. |
class |
OrderedInt32
An
int of 32-bits using a fixed-length encoding. |
class |
OrderedInt64
A
long of 64-bits using a fixed-length encoding. |
class |
OrderedInt8
A
byte of 8-bits using a fixed-length encoding. |
class |
OrderedNumeric
An
Number of arbitrary precision and variable-length encoding. |
class |
OrderedString
A
String of variable-length. |
class |
PBType<T extends com.google.protobuf.Message>
A base-class for
DataType implementations backed by protobuf. |
class |
RawByte
An
DataType for interacting with values encoded using
Bytes.putByte(byte[], int, byte) . |
class |
RawBytes
An
DataType for interacting with variable-length values
encoded using Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawBytesFixedLength
An
DataType that encodes fixed-length values encoded using
Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawBytesTerminated
An
DataType that encodes variable-length values encoded using
Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawDouble
An
DataType for interacting with values encoded using
Bytes.putDouble(byte[], int, double) . |
class |
RawFloat
An
DataType for interacting with values encoded using
Bytes.putFloat(byte[], int, float) . |
class |
RawInteger
An
DataType for interacting with values encoded using
Bytes.putInt(byte[], int, int) . |
class |
RawLong
An
DataType for interacting with values encoded using
Bytes.putLong(byte[], int, long) . |
class |
RawShort
An
DataType for interacting with values encoded using
Bytes.putShort(byte[], int, short) . |
class |
RawString
An
DataType for interacting with values encoded using
Bytes.toBytes(String) . |
class |
RawStringFixedLength
An
DataType that encodes fixed-length values encoded using
Bytes.toBytes(String) . |
class |
RawStringTerminated
An
DataType that encodes variable-length values encoded using
Bytes.toBytes(String) . |
class |
Struct
Struct is a simple DataType for implementing "compound
rowkey" and "compound qualifier" schema design strategies. |
class |
StructBuilder
A helper for building
Struct instances. |
class |
StructIterator
An
Iterator over encoded Struct members. |
class |
TerminatedWrapper<T>
Wraps an existing
DataType implementation as a terminated
version of itself. |
class |
Union2<A,B>
|
class |
Union3<A,B,C>
The
Union family of DataType s encode one of a fixed
collection of Objects. |
class |
Union4<A,B,C,D>
The
Union family of DataType s encode one of a fixed
collection of Objects. |
Modifier and Type | Class and Description |
---|---|
class |
Base64
Encodes and decodes to and from Base64 notation.
|
static class |
Base64.Base64InputStream
A
Base64.Base64InputStream will read data from another
InputStream, given in the constructor, and
encode/decode to/from Base64 notation on the fly. |
static class |
Base64.Base64OutputStream
A
Base64.Base64OutputStream will write data to another
OutputStream, given in the constructor, and
encode/decode to/from Base64 notation on the fly. |
class |
ByteBufferUtils
Utility functions for working with byte buffers, such as reading/writing
variable-length long numbers.
|
interface |
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
class |
ByteRangeUtils
Utility methods for working with
ByteRange . |
class |
Bytes
Utility class that handles byte arrays, conversions to/from other types,
comparisons, hash code generation, manufacturing keys for HashMaps or
HashSets, etc.
|
static class |
Bytes.ByteArrayComparator
Byte array comparator class.
|
static class |
Bytes.RowEndKeyComparator
A
Bytes.ByteArrayComparator that treats the empty array as the largest value. |
class |
Counter
High scalable counter.
|
class |
EncryptionTest |
class |
FileSystemVersionException
Thrown when the file system needs to be upgraded
|
class |
JsonMapper
Utility class for converting objects to JSON
|
class |
LeaseNotRecoveredException
Thrown when the lease was expected to be recovered,
but the file can't be opened.
|
class |
MD5Hash
Utility class for MD5
MD5 hash produces a 128-bit digest.
|
class |
Order
Used to describe or modify the lexicographical sort order of a
byte[] . |
class |
OrderedBytes
Utility class that handles ordered byte arrays.
|
class |
Pair<T1,T2>
A generic class for pairs.
|
class |
PairOfSameType<T>
A generic, immutable class for pairs of objects both of type
T . |
interface |
PositionedByteRange
Extends
ByteRange with additional methods to support tracking a
consumers position within the viewport. |
class |
ReadOnlyByteRangeException
Exception thrown when a read only byte range is modified
|
class |
SimpleByteRange
A read only version of the
ByteRange . |
class |
SimpleMutableByteRange
A basic mutable
ByteRange implementation. |
class |
SimplePositionedByteRange
Extends the basic
SimpleMutableByteRange implementation with position
support and it is a readonly version. |
class |
SimplePositionedMutableByteRange
Extends the basic
AbstractPositionedByteRange implementation with
position support and it is a mutable version. |
class |
VersionInfo
This class finds the Version information for HBase.
|
Constructor and Description |
---|
Base64.Base64OutputStream(OutputStream out,
int options)
Constructs a
Base64.Base64OutputStream in either ENCODE or DECODE mode. |
Modifier and Type | Class and Description |
---|---|
class |
MiniZooKeeperCluster
TODO: Most of the code in this class is ripped from ZooKeeper tests.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.