|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use InterfaceStability.Stable | |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client | Provides HBase Client |
org.apache.hadoop.hbase.client.coprocessor | Provides client classes for invoking Coprocessor RPC protocols |
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.filter | Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next() . |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.mapred | Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility |
org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication | Multi Cluster Replication |
org.apache.hadoop.hbase.rest | HBase REST |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.security | |
org.apache.hadoop.hbase.util |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase |
---|
Classes in org.apache.hadoop.hbase with annotations of type InterfaceStability.Stable | |
---|---|
class |
ClockOutOfSyncException
This exception is thrown by the master when a region server clock skew is too high. |
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 |
HConstants
HConstants holds a bunch of HBase-related constants |
class |
MasterNotRunningException
Thrown if the master is not running |
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 |
RegionException
Thrown when something happens related to region handling. |
class |
TableExistsException
Thrown when a table exists but should not |
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 |
YouAreDeadException
This exception is thrown by the master when a region server reports and is already being processed as dead. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.client |
---|
Classes in org.apache.hadoop.hbase.client with annotations of type InterfaceStability.Stable | |
---|---|
class |
Append
Performs Append operations on a single row. |
interface |
Attributes
|
class |
ClientScanner
Implements the scanner interface for the HBase client. |
class |
Delete
Used to perform Delete operations on a single row. |
class |
Get
Used to perform Get operations on a single row. |
class |
HTable
Used to communicate with a single HBase table. |
class |
HTableFactory
Deprecated. as of 0.98.1. See HConnectionManager.createConnection(Configuration) . |
interface |
HTableInterface
Used to communicate with a single HBase table. |
interface |
HTableInterfaceFactory
Defines methods to create new HTableInterface. |
class |
Increment
Used to perform Increment operations on a single row. |
class |
IsolationLevel
Specify Isolation levels in Scan operations. |
class |
NoServerForRegionException
Thrown when no region server can be found for a region |
class |
Put
Used to perform Put operations for a single row. |
class |
Result
Single row result of a Get or Scan query. |
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 |
Scan
Used to perform Scan operations. |
class |
ScannerTimeoutException
Thrown when a scanner has timed out. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.client.coprocessor |
---|
Classes in org.apache.hadoop.hbase.client.coprocessor with annotations of type InterfaceStability.Stable | |
---|---|
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. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.exceptions |
---|
Classes in org.apache.hadoop.hbase.exceptions with annotations of type InterfaceStability.Stable | |
---|---|
class |
FailedSanityCheckException
Exception thrown if a mutation fails sanity checks. |
class |
LockTimeoutException
|
class |
MergeRegionException
Thrown when something is wrong in trying to merge two regions. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.filter |
---|
Classes in org.apache.hadoop.hbase.filter with annotations of type InterfaceStability.Stable | |
---|---|
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 |
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 |
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. |
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. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.io |
---|
Classes in org.apache.hadoop.hbase.io with annotations of type InterfaceStability.Stable | |
---|---|
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. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.mapred |
---|
Classes in org.apache.hadoop.hbase.mapred with annotations of type InterfaceStability.Stable | |
---|---|
class |
Driver
Deprecated. |
class |
GroupingTableMap
Deprecated. |
class |
HRegionPartitioner<K2,V2>
Deprecated. |
class |
IdentityTableMap
Deprecated. |
class |
IdentityTableReduce
Deprecated. |
class |
RowCounter
Deprecated. |
class |
TableInputFormat
Deprecated. |
class |
TableInputFormatBase
Deprecated. |
interface |
TableMap<K extends WritableComparable<? super K>,V>
Deprecated. |
class |
TableMapReduceUtil
Deprecated. |
class |
TableOutputFormat
Deprecated. |
class |
TableRecordReader
Deprecated. |
class |
TableRecordReaderImpl
Deprecated. |
interface |
TableReduce<K extends WritableComparable,V>
Deprecated. |
class |
TableSplit
Deprecated. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.mapreduce |
---|
Classes in org.apache.hadoop.hbase.mapreduce with annotations of type InterfaceStability.Stable | |
---|---|
class |
CellCounter
A job with a a map and reduce phase to count cells in a table. |
class |
CopyTable
Tool used to copy a table to another one which can be on a different setup. |
class |
Driver
Driver for hbase mapreduce jobs. |
class |
Export
Export an HBase table. |
class |
GroupingTableMapper
Extract grouping columns from input record. |
class |
HFileOutputFormat
Deprecated. use HFileOutputFormat2 instead. |
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
Convenience class that simply writes all values (which must be Put or
Delete instances)
passed to it out to the configured HBase table. |
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 |
MultiTableOutputFormat
Hadoop output format that writes to one or more HBase tables. |
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 |
TsvImporterMapper
Write table content out to files in hdfs. |
class |
WALPlayer
A tool to replay WAL files as a M/R job. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.regionserver |
---|
Classes in org.apache.hadoop.hbase.regionserver with annotations of type InterfaceStability.Stable | |
---|---|
class |
RegionAlreadyInTransitionException
This exception is thrown when a region server is asked to open or close a region but it's already processing it |
interface |
RegionScanner
RegionScanner describes iterators over rows in an HRegion. |
class |
WrongRegionException
Thrown when a request contains a key which is not part of this region |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.replication |
---|
Classes in org.apache.hadoop.hbase.replication with annotations of type InterfaceStability.Stable | |
---|---|
class |
ReplicationException
An HBase Replication exception. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.rest |
---|
Classes in org.apache.hadoop.hbase.rest with annotations of type InterfaceStability.Stable | |
---|---|
interface |
Constants
Common constants for org.apache.hadoop.hbase.rest |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.rest.client |
---|
Classes in org.apache.hadoop.hbase.rest.client with annotations of type InterfaceStability.Stable | |
---|---|
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. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.security |
---|
Classes in org.apache.hadoop.hbase.security with annotations of type InterfaceStability.Stable | |
---|---|
class |
User
Wrapper to abstract out usage of user and group information in HBase. |
Uses of InterfaceStability.Stable in org.apache.hadoop.hbase.util |
---|
Classes in org.apache.hadoop.hbase.util with annotations of type InterfaceStability.Stable | |
---|---|
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 |
BoundedConcurrentLinkedQueue<T>
A ConcurrentLinkedQueue that enforces a maximum queue size. |
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 |
Hash
This class represents a common API for hashing functions. |
class |
HashedBytes
This class encapsulates a byte array and overrides hashCode and equals so that it's identity is based on the data rather than the array instance. |
class |
JenkinsHash
Produces 32-bit hash for hash table lookup. |
class |
JvmVersion
Certain JVM versions are known to be unstable with HBase. |
class |
MD5Hash
Utility class for MD5 MD5 hash produces a 128-bit digest. |
class |
MurmurHash
This is a very fast, non-cryptographic hash suitable for general hash-based lookup. |
class |
MurmurHash3
This is a very fast, non-cryptographic hash suitable for general hash-based lookup. |
class |
Pair<T1,T2>
A generic class for pairs. |
class |
PairOfSameType<T>
A generic, immutable class for pairs of objects both of type T . |
Constructors in org.apache.hadoop.hbase.util with annotations of type InterfaceStability.Stable | |
---|---|
Base64.Base64OutputStream(OutputStream out,
int options)
Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |