Uses of Class
org.apache.hadoop.hbase.classification.InterfaceAudience.Public

Packages that use InterfaceAudience.Public
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.classification   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.client.backoff   
org.apache.hadoop.hbase.client.coprocessor Provides client classes for invoking Coprocessor RPC protocols 
org.apache.hadoop.hbase.client.replication   
org.apache.hadoop.hbase.client.security   
org.apache.hadoop.hbase.coprocessor Table of Contents 
org.apache.hadoop.hbase.errorhandling   
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.io.compress   
org.apache.hadoop.hbase.io.crypto   
org.apache.hadoop.hbase.io.encoding   
org.apache.hadoop.hbase.io.hfile Provides the hbase data+index+metadata file. 
org.apache.hadoop.hbase.ipc Tools to help define network clients and servers. 
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.master   
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.wal   
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.security.access   
org.apache.hadoop.hbase.security.token   
org.apache.hadoop.hbase.security.visibility   
org.apache.hadoop.hbase.snapshot   
org.apache.hadoop.hbase.types This package provides the definition and implementation of HBase's extensible data type API. 
org.apache.hadoop.hbase.util   
org.apache.hadoop.hbase.util.hbck   
org.apache.hadoop.hbase.zookeeper   
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase
 

Classes in org.apache.hadoop.hbase with annotations of type InterfaceAudience.Public
 class AuthUtil
          Utility methods for helping with security tasks.
 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
          HRegion information.
 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 LocalHBaseCluster
          This class creates a single process HBase cluster.
 class MasterNotRunningException
          Thrown if the master is not running
 class NamespaceDescriptor
          Namespace POJO class.
 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 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 YouAreDeadException
          This exception is thrown by the master when a region server reports and is already being processed as dead.
 class ZooKeeperConnectionException
          Thrown if the client can't connect to zookeeper
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.classification
 

Classes in org.apache.hadoop.hbase.classification with annotations of type InterfaceAudience.Public
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.client
 

Classes in org.apache.hadoop.hbase.client with annotations of type InterfaceAudience.Public
 class Append
          Performs Append operations on a single row.
 interface Attributes
           
 class ClientScanner
          Implements the scanner interface for the HBase client.
 class ClientSmallReversedScanner
          Client scanner for small reversed scan.
 class ClientSmallScanner
          Client scanner for small scan.
 class Delete
          Used to perform Delete operations on a single row.
 class Durability
          Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
 class Get
          Used to perform Get operations on a single row.
 class HBaseAdmin
          Provides an interface to manage HBase database table metadata + general administrative functions.
 interface HConnection
          A cluster connection.
 class HConnectionManager
          A non-instantiable class that manages creation of HConnections.
 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 HTableMultiplexer
          HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
 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
           
 class RegionOfflineException
          Thrown when a table can not be located
 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.
 class ReversedClientScanner
          A reversed client scanner which support backward scanning
 class ReversedScannerCallable
          A reversed ScannerCallable which supports backward scanning.
 interface Row
          Has a row.
 class RowMutations
          Performs multiple mutations atomically on a single row.
 class Scan
          Used to perform Scan operations.
 class ScannerTimeoutException
          Thrown when a scanner has timed out.
 class TableSnapshotScanner
          A Scanner which performs a scan over snapshot files.
 class UnmodifyableHTableDescriptor
          Read-only table descriptor.
 class WrongRowIOException
           
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.client.backoff
 

Classes in org.apache.hadoop.hbase.client.backoff with annotations of type InterfaceAudience.Public
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.client.coprocessor
 

Classes in org.apache.hadoop.hbase.client.coprocessor with annotations of type InterfaceAudience.Public
 class Batch
          A collection of interfaces and utilities used for interacting with custom RPC interfaces exposed by Coprocessors.
 class DoubleColumnInterpreter
          a concrete column interpreter implementation.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.client.replication
 

Classes in org.apache.hadoop.hbase.client.replication with annotations of type InterfaceAudience.Public
 class ReplicationAdmin
           This class provides the administrative interface to HBase cluster replication.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.client.security
 

Classes in org.apache.hadoop.hbase.client.security with annotations of type InterfaceAudience.Public
 class SecurityCapability
          Available security capabilities
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.coprocessor
 

Classes in org.apache.hadoop.hbase.coprocessor with annotations of type InterfaceAudience.Public
 class CoprocessorException
          Thrown if a coprocessor encounters any exception.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.errorhandling
 

Classes in org.apache.hadoop.hbase.errorhandling with annotations of type InterfaceAudience.Public
 class ForeignException
          A ForeignException is an exception from another thread or process.
 class TimeoutException
          Exception for timeout of a task.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.exceptions
 

Classes in org.apache.hadoop.hbase.exceptions with annotations of type InterfaceAudience.Public
 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 RegionInRecoveryException
          Thrown when a read request issued against a region which is in recovering state.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.filter
 

Classes in org.apache.hadoop.hbase.filter with annotations of type InterfaceAudience.Public
 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 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 InterfaceAudience.Public in org.apache.hadoop.hbase.io
 

Classes in org.apache.hadoop.hbase.io with annotations of type InterfaceAudience.Public
 class ByteBufferOutputStream
          Not thread safe!
 class ImmutableBytesWritable
          A byte sequence that is usable as a key or value.
 class TimeRange
          Represents an interval of version timestamps.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.io.compress
 

Classes in org.apache.hadoop.hbase.io.compress with annotations of type InterfaceAudience.Public
static class Compression.Algorithm
          Compression algorithms.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.io.crypto
 

Classes in org.apache.hadoop.hbase.io.crypto with annotations of type InterfaceAudience.Public
 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.
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.io.encoding
 

Classes in org.apache.hadoop.hbase.io.encoding with annotations of type InterfaceAudience.Public
 class DataBlockEncoding
          Provide access to all data block encoding algorithms.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.io.hfile
 

Classes in org.apache.hadoop.hbase.io.hfile with annotations of type InterfaceAudience.Public
 class HFilePrettyPrinter
          Implements pretty-printing functionality for HFiles.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.ipc
 

Classes in org.apache.hadoop.hbase.ipc with annotations of type InterfaceAudience.Public
 class BadAuthException
           
 class CallerDisconnectedException
          Exception indicating that the remote host making this IPC lost its IPC connection.
 class CoprocessorRpcChannel
          Base class which provides clients with an RPC connection to call coprocessor endpoint Services.
 class FatalConnectionException
          Thrown when server finds fatal issue w/ connection setup: e.g.
 class RemoteWithExtrasException
          A RemoteException with some extra information.
static class RpcClient.CallTimeoutException
          Client-side call timeout
static class RpcClient.FailedServerException
           
 class ServerNotRunningYetException
           
 class StoppedRpcClientException
           
 class UnsupportedCellCodecException
           
 class UnsupportedCompressionCodecException
           
 class WrongVersionException
           
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.mapred
 

Classes in org.apache.hadoop.hbase.mapred with annotations of type InterfaceAudience.Public
 class Driver
          Deprecated. 
 class GroupingTableMap
          Deprecated. 
 class HRegionPartitioner<K2,V2>
          Deprecated. 
 class IdentityTableMap
          Deprecated. 
 class IdentityTableReduce
          Deprecated. 
 class MultiTableSnapshotInputFormat
          MultiTableSnapshotInputFormat generalizes .TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
 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 TableSnapshotInputFormat
          TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
 class TableSplit
          Deprecated. 
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.mapreduce
 

Classes in org.apache.hadoop.hbase.mapreduce with annotations of type InterfaceAudience.Public
 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 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 HFileOutputFormat2
          Writes HFiles.
 class HLogInputFormat
          Simple InputFormat for HLog files.
 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 MultiTableInputFormat
          Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
 class MultiTableInputFormatBase
          A base for MultiTableInputFormats.
 class MultiTableOutputFormat
           Hadoop output format that writes to one or more HBase tables.
 class MultiTableSnapshotInputFormat
          MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
 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 TableInputFormats.
 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 WALPlayer
          A tool to replay WAL files as a M/R job.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.master
 

Classes in org.apache.hadoop.hbase.master with annotations of type InterfaceAudience.Public
static class RegionState.State
           
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.regionserver
 

Classes in org.apache.hadoop.hbase.regionserver with annotations of type InterfaceAudience.Public
 class BloomType
           
 class CompactionTool
           
 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 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 WrongRegionException
          Thrown when a request contains a key which is not part of this region
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.regionserver.wal
 

Classes in org.apache.hadoop.hbase.regionserver.wal with annotations of type InterfaceAudience.Public
 class FailedLogCloseException
          Thrown when we fail close of the write-ahead-log file.
 class HLogPrettyPrinter
          HLogPrettyPrinter prints the contents of a given HLog with a variety of options affecting formatting and extent of content.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.replication
 

Classes in org.apache.hadoop.hbase.replication with annotations of type InterfaceAudience.Public
 class ReplicationException
          An HBase Replication exception.
 class ReplicationPeerConfig
          A configuration for the replication peer cluster.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.rest
 

Classes in org.apache.hadoop.hbase.rest with annotations of type InterfaceAudience.Public
 interface Constants
          Common constants for org.apache.hadoop.hbase.rest
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.rest.client
 

Classes in org.apache.hadoop.hbase.rest.client with annotations of type InterfaceAudience.Public
 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 InterfaceAudience.Public in org.apache.hadoop.hbase.security
 

Classes in org.apache.hadoop.hbase.security with annotations of type InterfaceAudience.Public
 class AccessDeniedException
          Exception thrown by access-related methods.
 class User
          Wrapper to abstract out usage of user and group information in HBase.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.security.access
 

Classes in org.apache.hadoop.hbase.security.access with annotations of type InterfaceAudience.Public
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.security.token
 

Classes in org.apache.hadoop.hbase.security.token with annotations of type InterfaceAudience.Public
 class TokenUtil
          Utility methods for obtaining authentication tokens.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.security.visibility
 

Classes in org.apache.hadoop.hbase.security.visibility with annotations of type InterfaceAudience.Public
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.snapshot
 

Classes in org.apache.hadoop.hbase.snapshot with annotations of type InterfaceAudience.Public
 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.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.types
 

Classes in org.apache.hadoop.hbase.types with annotations of type InterfaceAudience.Public
 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 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>
          The Union family of DataTypes encode one of a fixed set of Objects.
 class Union3<A,B,C>
          The Union family of DataTypes encode one of a fixed collection of Objects.
 class Union4<A,B,C,D>
          The Union family of DataTypes encode one of a fixed collection of Objects.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.util
 

Classes in org.apache.hadoop.hbase.util with annotations of type InterfaceAudience.Public
 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.
 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 CompressionTest
          Compression validation test.
 class ConfigurationUtil
          Utilities for storing more complex collection types in Configuration instances.
 class EncryptionTest
           
 class FileSystemVersionException
          Thrown when the file system needs to be upgraded
 class HBaseFsck
          HBaseFsck (hbck) is a tool for checking and repairing region consistency and table integrity problems in a corrupted HBase.
 class JsonMapper
          Utility class for converting objects to JSON
 class MD5Hash
          Utility class for MD5 MD5 hash produces a 128-bit digest.
 class Merge
          Utility that can merge any two regions in the same table: adjacent, overlapping or disjoint.
 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 PrettyPrinter
           
 class SimpleByteRange
          A basic ByteRange implementation.
 class SimplePositionedByteRange
          Extends the basic SimpleByteRange implementation with position support.
 class VersionInfo
          This class finds the package info for hbase and the VersionAnnotation information.
 

Constructors in org.apache.hadoop.hbase.util with annotations of type InterfaceAudience.Public
Base64.Base64OutputStream(OutputStream out, int options)
          Constructs a Base64.Base64OutputStream in either ENCODE or DECODE mode.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.util.hbck
 

Classes in org.apache.hadoop.hbase.util.hbck with annotations of type InterfaceAudience.Public
 class OfflineMetaRepair
          This code is used to rebuild meta off line from file system data.
 

Uses of InterfaceAudience.Public in org.apache.hadoop.hbase.zookeeper
 

Classes in org.apache.hadoop.hbase.zookeeper with annotations of type InterfaceAudience.Public
 class HQuorumPeer
          HBase's version of ZooKeeper's QuorumPeer.
 class MiniZooKeeperCluster
          TODO: Most of the code in this class is ripped from ZooKeeper tests.
 class ZKServerTool
          Tool for reading ZooKeeper servers from HBase XML configuration and producing a line-by-line list for use by bash scripts.
 



Copyright © 2007–2015 The Apache Software Foundation. All rights reserved.