Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.hadoop.hbase Classes and Interfaces - 335 results found.
NameDescriptionTypePackageFramework
AccessDeniedExceptionException thrown by access-related methods.Classorg.apache.hadoop.hbase.securityHBase
AdminThe administrative API for HBase.Interfaceorg.apache.hadoop.hbase.clientHBase
Admin .CompactTypeCurrently, there are only two compact types: NORMAL means do store files compaction;Classorg.apache.hadoop.hbase.client.AdminHBase
AppendPerforms Append operations on a single row.Classorg.apache.hadoop.hbase.clientHBase
AttributesInterfaceorg.apache.hadoop.hbase.clientHBase
BadAuthExceptionClassorg.apache.hadoop.hbase.ipcHBase
Base64Encodes and decodes to and from Base64 notation.Classorg.apache.hadoop.hbase.utilHBase
Base64 .Base64InputStreamA Base64.Classorg.apache.hadoop.hbase.util.Base64HBase
Base64 .Base64OutputStreamA Base64.Classorg.apache.hadoop.hbase.util.Base64HBase
BinaryComparatorA binary comparator which lexicographically compares against the specified byte array using Bytes.Classorg.apache.hadoop.hbase.filterHBase
BinaryPrefixComparatorA comparator which compares against a specified byte array, but only compares up to the length of this byte array.Classorg.apache.hadoop.hbase.filterHBase
BitComparatorA bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.Classorg.apache.hadoop.hbase.filterHBase
BitComparator .BitwiseOpClassorg.apache.hadoop.hbase.filter.BitComparatorHBase
BloomTypeClassorg.apache.hadoop.hbase.regionserverHBase
BufferedMutatorUsed to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.Interfaceorg.apache.hadoop.hbase.clientHBase
BufferedMutator .ExceptionListenerListens for asynchronous exceptions on a BufferedMutator.Interfaceorg.apache.hadoop.hbase.client.BufferedMutatorHBase
BufferedMutatorParamsParameters for instantiating a BufferedMutator.Classorg.apache.hadoop.hbase.clientHBase
BypassCoprocessorExceptionThrown if a coprocessor rules we should bypass an operationSee Also:Serialized FormClassorg.apache.hadoop.hbase.coprocessorHBase
ByteArrayComparableClassorg.apache.hadoop.hbase.filterHBase
ByteBufferOutputStreamClassorg.apache.hadoop.hbase.ioHBase
ByteBufferUtilsUtility functions for working with byte buffers, such as reading/writing variable-length long numbers.Classorg.apache.hadoop.hbase.utilHBase
ByteRangeLightweight, reusable class for specifying ranges of byte[]'s.Interfaceorg.apache.hadoop.hbase.utilHBase
ByteRangeUtilsUtility methods for working with ByteRange.Classorg.apache.hadoop.hbase.utilHBase
BytesUtility class that handles byte arrays, conversions to/from other types, comparisons, hash code generation, manufacturing keys for HashMaps orClassorg.apache.hadoop.hbase.utilHBase
Bytes .ByteArrayComparatorByte array comparator class.Classorg.apache.hadoop.hbase.util.BytesHBase
Bytes .RowEndKeyComparatorA Bytes.Classorg.apache.hadoop.hbase.util.BytesHBase
CallerDisconnectedExceptionException indicating that the remote host making this IPC lost its IPC connection.Classorg.apache.hadoop.hbase.ipcHBase
CallQueueTooBigExceptionClassorg.apache.hadoop.hbaseHBase
CallTimeoutExceptionClient-side call timeoutSee Also:Serialized FormClassorg.apache.hadoop.hbase.ipcHBase
CellThe unit of storage in HBase consisting of the following fields: 3) column qualifierInterfaceorg.apache.hadoop.hbaseHBase
CellCounterA job with a a map and reduce phase to count cells in a table.Classorg.apache.hadoop.hbase.mapreduceHBase
CellCreatorFacade to create Cells for HFileOutputFormat.Classorg.apache.hadoop.hbase.mapreduceHBase
CellUtilUtility methods helpful slinging Cell instances.Classorg.apache.hadoop.hbaseHBase
CipherA common interface for a cryptographic algorithm.Classorg.apache.hadoop.hbase.io.cryptoHBase
CipherProviderInterfaceorg.apache.hadoop.hbase.io.cryptoHBase
ClientA wrapper around HttpClient which provides some useful function and semantics for interacting with the REST gateway.Classorg.apache.hadoop.hbase.rest.clientHBase
ClientBackoffPolicyConfigurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.Interfaceorg.apache.hadoop.hbase.client.backoffHBase
ClockOutOfSyncExceptionThis exception is thrown by the master when a region server clock skew isSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
ClusterA list of 'host:port' addresses of HTTP servers operating as a single entity, for example multiple redundant web service gateways.Classorg.apache.hadoop.hbase.rest.clientHBase
ClusterStatusStatus information on the HBase cluster.Classorg.apache.hadoop.hbaseHBase
ColumnCountGetFilterSimple filter that returns first N columns on row only.Classorg.apache.hadoop.hbase.filterHBase
ColumnPaginationFilterA filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.Classorg.apache.hadoop.hbase.filterHBase
ColumnPrefixFilterThis filter is used for selecting only those keys with columns that matches a particular prefix.Classorg.apache.hadoop.hbase.filterHBase
ColumnRangeFilterThis filter is used for selecting only those keys with columns that are between minColumn to maxColumn.Classorg.apache.hadoop.hbase.filterHBase
CompareFilterThis is a generic filter to be used to filter by comparison.Classorg.apache.hadoop.hbase.filterHBase
CompareFilter .CompareOpComparison operators.Classorg.apache.hadoop.hbase.filter.CompareFilterHBase
ConfigurationUtilUtilities for storing more complex collection types in Configuration instances.Classorg.apache.hadoop.hbase.utilHBase
ConnectionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Interfaceorg.apache.hadoop.hbase.clientHBase
ConnectionClosingExceptionThrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.Classorg.apache.hadoop.hbase.exceptionsHBase
ConnectionFactoryA non-instantiable class that manages creation of Connections.Classorg.apache.hadoop.hbase.clientHBase
ConsistencyConsistency defines the expected consistency level for an operation.Classorg.apache.hadoop.hbase.clientHBase
ConstantsCommon constants for org.Interfaceorg.apache.hadoop.hbase.restHBase
ContextCrypto context.Classorg.apache.hadoop.hbase.io.cryptoHBase
CoprocessorExceptionThrown if a coprocessor encounters any exception.Classorg.apache.hadoop.hbase.coprocessorHBase
CoprocessorRpcChannelBase class which provides clients with an RPC connection to call coprocessor endpoint Services.Classorg.apache.hadoop.hbase.ipcHBase
CopyTableTool used to copy a table to another one which can be on a different setup.Classorg.apache.hadoop.hbase.mapreduceHBase
CorruptedSnapshotExceptionException thrown when the found snapshot info from the filesystem is not validSee Also:Serialized FormClassorg.apache.hadoop.hbase.snapshotHBase
CounterHigh scalable counter.Classorg.apache.hadoop.hbase.utilHBase
DataBlockEncodingenum DataBlockEncodingProvide access to all data block encoding algorithms.Classorg.apache.hadoop.hbase.io.encodingHBase
DataType DataType is the base class for all HBase data types.Interfaceorg.apache.hadoop.hbase.typesHBase
DecryptorDecryptors apply a cipher to an InputStream to recover plaintext.Interfaceorg.apache.hadoop.hbase.io.cryptoHBase
DefaultCipherProviderThe default cipher provider.Classorg.apache.hadoop.hbase.io.cryptoHBase
DeleteUsed to perform Delete operations on a single row.Classorg.apache.hadoop.hbase.clientHBase
DependentColumnFilterA filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry inClassorg.apache.hadoop.hbase.filterHBase
DoNotRetryIOExceptionSubclass if exception is not meant to be retried: e.Classorg.apache.hadoop.hbaseHBase
DoNotRetryRegionExceptionSimilar to RegionException, but disables retries.Classorg.apache.hadoop.hbase.clientHBase
DroppedSnapshotExceptionThrown during flush if the possibility snapshot content was not properly persisted into store files.Classorg.apache.hadoop.hbaseHBase
DurabilityEnum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durabilityClassorg.apache.hadoop.hbase.clientHBase
EncryptionA facade for encryption algorithms and related support.Classorg.apache.hadoop.hbase.io.cryptoHBase
Encryption .ContextClassorg.apache.hadoop.hbase.io.crypto.EncryptionHBase
EncryptionTestClassorg.apache.hadoop.hbase.utilHBase
EncryptorEncryptors apply a cipher to an OutputStream to produce ciphertext.Interfaceorg.apache.hadoop.hbase.io.cryptoHBase
ExponentialClientBackoffPolicySimple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.Classorg.apache.hadoop.hbase.client.backoffHBase
ExportExport an HBase table.Classorg.apache.hadoop.hbase.mapreduceHBase
ExportSnapshotExport the specified snapshot to a given FileSystem.Classorg.apache.hadoop.hbase.snapshotHBase
ExportSnapshotExceptionThrown when a snapshot could not be exported due to an error during the operation.Classorg.apache.hadoop.hbase.snapshotHBase
FailedLogCloseExceptionThrown when we fail close of the write-ahead-log file.Classorg.apache.hadoop.hbase.regionserver.walHBase
FailedSanityCheckExceptionException thrown if a mutation fails sanity checks.Classorg.apache.hadoop.hbase.exceptionsHBase
FailedServerExceptionIndicates that we're trying to connect to a already known as dead server.Classorg.apache.hadoop.hbase.ipcHBase
FailedSyncBeforeLogCloseExceptionThrown when we fail close of the write-ahead-log file.Classorg.apache.hadoop.hbase.regionserver.walHBase
FamilyFilter This filter is used to filter based on the column family.Classorg.apache.hadoop.hbase.filterHBase
FastLongHistogramClassorg.apache.hadoop.hbase.utilHBase
FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.Classorg.apache.hadoop.hbase.ipcHBase
FileSystemVersionExceptionThrown when the file system needs to be upgradedSee Also:Serialized FormClassorg.apache.hadoop.hbase.utilHBase
FilterInterface for row and column filters directly applied within the regionserver.Classorg.apache.hadoop.hbase.filterHBase
Filter .ReturnCodeReturn codes for filterValue().Classorg.apache.hadoop.hbase.filter.FilterHBase
FilterList which will be evaluated with a specified boolean operator FilterList.Classorg.apache.hadoop.hbase.filterHBase
FilterList .OperatorClassorg.apache.hadoop.hbase.filter.FilterListHBase
FirstKeyOnlyFilterA filter that will only return the first KV from each row.Classorg.apache.hadoop.hbase.filterHBase
FirstKeyValueMatchingQualifiersFilterThe filter looks for the given columns in KeyValue.Classorg.apache.hadoop.hbase.filterHBase
FixedLengthWrapperWraps an existing DataType implementation as a fixed-length version of itself.Classorg.apache.hadoop.hbase.typesHBase
ForeignExceptionA ForeignException is an exception from another thread or process.Classorg.apache.hadoop.hbase.errorhandlingHBase
FuzzyRowFilterThis is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.Classorg.apache.hadoop.hbase.filterHBase
GetUsed to perform Get operations on a single row.Classorg.apache.hadoop.hbase.clientHBase
GroupingTableMapClassorg.apache.hadoop.hbase.mapredHBase
GroupingTableMapperExtract grouping columns from input record.Classorg.apache.hadoop.hbase.mapreduceHBase
HBaseConfigurationClassorg.apache.hadoop.hbaseHBase
HBaseInterfaceAudienceClassorg.apache.hadoop.hbaseHBase
HBaseIOExceptionAll hbase specific IOExceptions should be subclasses of HBaseIOExceptionSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
HBaseSnapshotExceptionGeneral exception base class for when a snapshot failsSee Also:Serialized FormClassorg.apache.hadoop.hbase.snapshotHBase
HColumnDescriptorAn HColumnDescriptor contains information about a column family such as the number of versions, compression settings, etc.Classorg.apache.hadoop.hbaseHBase
HConnectionA cluster connection.Interfaceorg.apache.hadoop.hbase.clientHBase
HConstantsClassorg.apache.hadoop.hbaseHBase
HFileOutputFormat2Writes HFiles.Classorg.apache.hadoop.hbase.mapreduceHBase
HLogInputFormatClassorg.apache.hadoop.hbase.mapreduceHBase
HRegionInfoInformation about a region.Classorg.apache.hadoop.hbaseHBase
HRegionLocationData structure to hold HRegionInfo and the address for the hosting HRegionServer.Classorg.apache.hadoop.hbaseHBase
HRegionPartitionerThis is used to partition the output keys into groups of keys.Classorg.apache.hadoop.hbase.mapredHBase
HRegionPartitionerThis is used to partition the output keys into groups of keys.Classorg.apache.hadoop.hbase.mapreduceHBase
HTableDescriptorHTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, -ROOT- orClassorg.apache.hadoop.hbaseHBase
HTableMultiplexerHTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.Classorg.apache.hadoop.hbase.clientHBase
HTableMultiplexer .HTableMultiplexerStatusHTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.Classorg.apache.hadoop.hbase.client.HTableMultiplexerHBase
IdentityTableMapClassorg.apache.hadoop.hbase.mapredHBase
IdentityTableMapperPass the given key and record as-is to the reduce phase.Classorg.apache.hadoop.hbase.mapreduceHBase
IdentityTableReduceClassorg.apache.hadoop.hbase.mapredHBase
IdentityTableReducerConvenience class that simply writes all values (which must be passed to it out to the configured HBase table.Classorg.apache.hadoop.hbase.mapreduceHBase
ImmutableBytesWritableA byte sequence that is usable as a key or value.Classorg.apache.hadoop.hbase.ioHBase
ImmutableBytesWritable .ComparatorA Comparator optimized for ImmutableBytesWritable.Classorg.apache.hadoop.hbase.io.ImmutableBytesWritableHBase
ImportImport data written by Export.Classorg.apache.hadoop.hbase.mapreduceHBase
ImportTsvTool to import data from a TSV file.Classorg.apache.hadoop.hbase.mapreduceHBase
InclusiveStopFilterA Filter that stops after the given row.Classorg.apache.hadoop.hbase.filterHBase
IncompatibleFilterExceptionUsed to indicate a filter incompatibilitySee Also:Serialized FormClassorg.apache.hadoop.hbase.filterHBase
IncrementUsed to perform Increment operations on a single row.Classorg.apache.hadoop.hbase.clientHBase
InterfaceAudienceAnnotation to inform users of a package, class or method's intended audience.Classorg.apache.hadoop.hbase.classificationHBase
InterfaceStabilityAnnotation to inform users of how much to rely on a particular package, class or method not changing over time.Classorg.apache.hadoop.hbase.classificationHBase
InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but made for an invalid family name.Classorg.apache.hadoop.hbaseHBase
InvalidRowFilterExceptionUsed to indicate an invalid RowFilter.Classorg.apache.hadoop.hbase.filterHBase
IsolationLevelSpecify Isolation levels in Scan operations.Classorg.apache.hadoop.hbase.clientHBase
JsonMapperClassorg.apache.hadoop.hbase.utilHBase
KeepDeletedCellsenum KeepDeletedCellsWays to keep cells marked for delete around.Classorg.apache.hadoop.hbaseHBase
KeyOnlyFilterA filter that will only return the key component of each KV (the value will be rewritten as empty).Classorg.apache.hadoop.hbase.filterHBase
KeyProviderKeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.Interfaceorg.apache.hadoop.hbase.io.cryptoHBase
KeyStoreKeyProviderA basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.Classorg.apache.hadoop.hbase.io.cryptoHBase
KeyValueSortReducerEmits sorted KeyValues.Classorg.apache.hadoop.hbase.mapreduceHBase
LeaseExceptionReports a problem with a leaseSee Also:Serialized FormClassorg.apache.hadoop.hbase.regionserverHBase
LeaseNotRecoveredExceptionThrown when the lease was expected to be recovered, but the file can't be opened.Classorg.apache.hadoop.hbase.utilHBase
LoadIncrementalHFilesTool to load the output of HFileOutputFormat into an existing table.Classorg.apache.hadoop.hbase.mapreduceHBase
LocalHBaseClusterThis class creates a single process HBase cluster.Classorg.apache.hadoop.hbaseHBase
LockTimeoutExceptionThrown when there is a timeout when trying to acquire a lockSee Also:Serialized FormClassorg.apache.hadoop.hbase.exceptionsHBase
LongComparatorClassorg.apache.hadoop.hbase.filterHBase
MasterNotRunningExceptionThrown if the master is not runningSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
MD5HashUtility class for MD5 MD5 hash produces a 128-bit digest.Classorg.apache.hadoop.hbase.utilHBase
MergeRegionExceptionThrown when something is wrong in trying to merge two regions.Classorg.apache.hadoop.hbase.exceptionsHBase
MiniZooKeeperClusterTODO: Most of the code in this class is ripped from ZooKeeper tests.Classorg.apache.hadoop.hbase.zookeeperHBase
MobConstantsThe constants used in mob.Classorg.apache.hadoop.hbase.mobHBase
MultiActionResultTooLargeException thrown when the result needs to be chunked on the server side.Classorg.apache.hadoop.hbaseHBase
MultipleColumnPrefixFilterThis filter is used for selecting only those keys with columns that matches a particular prefix.Classorg.apache.hadoop.hbase.filterHBase
MultiRowRangeFilterFilter to support scan multiple row key ranges.Classorg.apache.hadoop.hbase.filterHBase
MultiRowRangeFilter .RowRangeClassorg.apache.hadoop.hbase.filter.MultiRowRangeFilterHBase
MultiTableInputFormatConvert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.Classorg.apache.hadoop.hbase.mapreduceHBase
MultiTableInputFormatBaseA base for MultiTableInputFormats.Classorg.apache.hadoop.hbase.mapreduceHBase
MultiTableOutputFormat Hadoop output format that writes to one or more HBase tables.Classorg.apache.hadoop.hbase.mapreduceHBase
MultiTableSnapshotInputFormatMultiTableSnapshotInputFormat generalizes .Classorg.apache.hadoop.hbase.mapredHBase
MultiTableSnapshotInputFormatMultiTableSnapshotInputFormat generalizes TableSnapshotInputFormatClassorg.apache.hadoop.hbase.mapreduceHBase
MutationClassorg.apache.hadoop.hbase.clientHBase
NamespaceDescriptorNamespace POJO class.Classorg.apache.hadoop.hbaseHBase
NamespaceDescriptor .BuilderClassorg.apache.hadoop.hbase.NamespaceDescriptorHBase
NamespaceExistExceptionThrown when a namespace exists but should notSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
NamespaceNotFoundExceptionThrown when a namespace can not be locatedSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
NoServerForRegionExceptionThrown when no region server can be found for a regionSee Also:Serialized FormClassorg.apache.hadoop.hbase.clientHBase
NoSuchColumnFamilyExceptionThrown if request for nonexistent column family.Classorg.apache.hadoop.hbase.regionserverHBase
NotAllMetaRegionsOnlineExceptionThrown when an operation requires the root and all meta regions to be onlineSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
NotServingRegionExceptionThrown by a region server if it is sent a request for a region it is notSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
NullComparatorA binary comparator which lexicographically compares against the specified byte array using Bytes.Classorg.apache.hadoop.hbase.filterHBase
OperationSuperclass for any type that maps to a potentially application-level query.Classorg.apache.hadoop.hbase.clientHBase
OperationConflictExceptionThe exception that is thrown if there's duplicate execution of non-idempotent operation.Classorg.apache.hadoop.hbase.exceptionsHBase
OperationWithAttributesClassorg.apache.hadoop.hbase.clientHBase
OrderUsed to describe or modify the lexicographical sort order of a byte[].Classorg.apache.hadoop.hbase.utilHBase
OrderedBlobA byte[] of variable-length.Classorg.apache.hadoop.hbase.typesHBase
OrderedBlobVarAn alternative to OrderedBlob for use by Struct fields that do not terminate the fields list.Classorg.apache.hadoop.hbase.typesHBase
OrderedBytesUtility class that handles ordered byte arrays.Classorg.apache.hadoop.hbase.utilHBase
OrderedBytesBaseClassorg.apache.hadoop.hbase.typesHBase
OrderedFloat32A float of 32-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedFloat64A double of 64-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedInt16A short of 16-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedInt32An int of 32-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedInt64A long of 64-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedInt8A byte of 8-bits using a fixed-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedNumericAn Number of arbitrary precision and variable-length encoding.Classorg.apache.hadoop.hbase.typesHBase
OrderedStringA String of variable-length.Classorg.apache.hadoop.hbase.typesHBase
PageFilter size.Classorg.apache.hadoop.hbase.filterHBase
PairA generic class for pairs.Classorg.apache.hadoop.hbase.utilHBase
PairOfSameTypeA generic, immutable class for pairs of objects both of type T.Classorg.apache.hadoop.hbase.utilHBase
ParseConstantsParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilterClassorg.apache.hadoop.hbase.filterHBase
ParseFilterThis class allows a user to specify a filter via a string The string is parsed using the methods of this class andClassorg.apache.hadoop.hbase.filterHBase
PBTypeA base-class for DataType implementations backed by protobuf.Classorg.apache.hadoop.hbase.typesHBase
PleaseHoldExceptionThis 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 shutdownClassorg.apache.hadoop.hbaseHBase
PositionedByteRange Extends ByteRange with additional methods to support tracking a consumers position within the viewport.Interfaceorg.apache.hadoop.hbase.utilHBase
PreemptiveFastFailExceptionThrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.Classorg.apache.hadoop.hbase.exceptionsHBase
PrefixFilterPass results that have same row prefix.Classorg.apache.hadoop.hbase.filterHBase
ProcedureInfoClassorg.apache.hadoop.hbaseHBase
PutUsed to perform Put operations for a single row.Classorg.apache.hadoop.hbase.clientHBase
PutCombinerCombine Puts.Classorg.apache.hadoop.hbase.mapreduceHBase
PutSortReducer Reads in all Puts from passed Iterator, sorts them, then emits Puts in sorted order.Classorg.apache.hadoop.hbase.mapreduceHBase
QualifierFilterThis filter is used to filter based on the column qualifier.Classorg.apache.hadoop.hbase.filterHBase
QueryClassorg.apache.hadoop.hbase.clientHBase
QuotaExceededExceptionGeneric quota exceeded exceptionSee Also:Serialized FormClassorg.apache.hadoop.hbase.quotasHBase
QuotaFilterFilter to use to filter the QuotaRetriever results.Classorg.apache.hadoop.hbase.quotasHBase
QuotaRetrieverScanner to iterate over the quota settings.Classorg.apache.hadoop.hbase.quotasHBase
QuotaScopeDescribe the Scope of the quota rules.Classorg.apache.hadoop.hbase.quotasHBase
QuotaSettingsClassorg.apache.hadoop.hbase.quotasHBase
QuotaSettingsFactoryClassorg.apache.hadoop.hbase.quotasHBase
QuotaTypeDescribe the Quota Type.Classorg.apache.hadoop.hbase.quotasHBase
RandomRowFilterA filter that includes rows based on a chance.Classorg.apache.hadoop.hbase.filterHBase
RawByteAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawBytesAn DataType for interacting with variable-length values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawBytesFixedLengthAn DataType that encodes fixed-length values encoded using byte[], int, byte[], int, int).Classorg.apache.hadoop.hbase.typesHBase
RawBytesTerminatedAn DataType that encodes variable-length values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawDoubleAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawFloatAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawIntegerAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawLongAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawShortAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawStringAn DataType for interacting with values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawStringFixedLengthAn DataType that encodes fixed-length values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
RawStringTerminatedAn DataType that encodes variable-length values encoded using Bytes.Classorg.apache.hadoop.hbase.typesHBase
ReadOnlyByteRangeExceptionException thrown when a read only byte range is modifiedSee Also:Serialized FormClassorg.apache.hadoop.hbase.utilHBase
RegexStringComparatorThis comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, forClassorg.apache.hadoop.hbase.filterHBase
RegexStringComparator .EngineTypeClassorg.apache.hadoop.hbase.filter.RegexStringComparatorHBase
RegionExceptionThrown when something happens related to region handling.Classorg.apache.hadoop.hbaseHBase
RegionInRecoveryExceptionThrown when a read request issued against a region which is in recovering state.Classorg.apache.hadoop.hbase.exceptionsHBase
RegionLoadEncapsulates per-region load metrics.Classorg.apache.hadoop.hbaseHBase
RegionLocatorUsed to view region location information for a single HBase table.Interfaceorg.apache.hadoop.hbase.clientHBase
RegionMoverTool for loading/unloading regions to/from given regionserver This tool can be run from Command line directly as a utility.Classorg.apache.hadoop.hbase.utilHBase
RegionOfflineExceptionThrown when a table can not be locatedSee Also:Serialized FormClassorg.apache.hadoop.hbase.clientHBase
RegionServerAbortedExceptionThrown by the region server when it is aborting.Classorg.apache.hadoop.hbase.regionserverHBase
RegionServerRunningExceptionThrown if the region server log directory exists (which indicates another region server is running at the same address)Classorg.apache.hadoop.hbase.regionserverHBase
RegionServerStoppedExceptionThrown by the region server when it is in shutting down state.Classorg.apache.hadoop.hbase.regionserverHBase
RegionTooBusyExceptionThrown by a region server if it will block and wait to serve a request.Classorg.apache.hadoop.hbaseHBase
RemoteAdminClassorg.apache.hadoop.hbase.rest.clientHBase
RemoteHTableClassorg.apache.hadoop.hbase.rest.clientHBase
RemoteWithExtrasExceptionA RemoteException with some extra information.Classorg.apache.hadoop.hbase.ipcHBase
ReplicationAdmin This class provides the administrative interface to HBase cluster replication.Classorg.apache.hadoop.hbase.client.replicationHBase
ReplicationExceptionAn HBase Replication exception.Classorg.apache.hadoop.hbase.replicationHBase
ReplicationPeerConfigA configuration for the replication peer cluster.Classorg.apache.hadoop.hbase.replicationHBase
ResponseThe HTTP result code, response headers, and body of a HTTP response.Classorg.apache.hadoop.hbase.rest.clientHBase
RestoreSnapshotExceptionThrown when a snapshot could not be restored due to a server-side error when restoring it.Classorg.apache.hadoop.hbase.snapshotHBase
ResultSingle row result of a Get or Scan query.Classorg.apache.hadoop.hbase.clientHBase
ResultScannerInterface for client-side scanning.Interfaceorg.apache.hadoop.hbase.clientHBase
RetriesExhaustedExceptionException thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.Classorg.apache.hadoop.hbase.clientHBase
RetriesExhaustedWithDetailsExceptionThis subclass of RetriesExhaustedException is thrown when we have more information about which rows were causing whichClassorg.apache.hadoop.hbase.clientHBase
RetryImmediatelyExceptionClassorg.apache.hadoop.hbaseHBase
RowInterfaceorg.apache.hadoop.hbase.clientHBase
RowCounterA job with a map to count rows.Classorg.apache.hadoop.hbase.mapredHBase
RowCounterA job with a just a map phase to count rows.Classorg.apache.hadoop.hbase.mapreduceHBase
RowFilterThis filter is used to filter based on the key.Classorg.apache.hadoop.hbase.filterHBase
RowMutationsPerforms multiple mutations atomically on a single row.Classorg.apache.hadoop.hbase.clientHBase
RowTooBigExceptionGets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable viaClassorg.apache.hadoop.hbase.clientHBase
RowTooBigExceptionGets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable viaClassorg.apache.hadoop.hbase.regionserverHBase
RpcRetryingCallerInterfaceorg.apache.hadoop.hbase.clientHBase
ScanUsed to perform Scan operations.Classorg.apache.hadoop.hbase.clientHBase
ScannerTimeoutExceptionThrown when a scanner has timed out.Classorg.apache.hadoop.hbase.clientHBase
SecurityCapabilityenum SecurityCapabilityAvailable security capabilitiesClassorg.apache.hadoop.hbase.client.securityHBase
ServerLoadThis class is used for exporting current state of load on a RegionServer.Classorg.apache.hadoop.hbaseHBase
ServerNameInstance of an HBase ServerName.Classorg.apache.hadoop.hbaseHBase
ServerNotRunningYetExceptionClassorg.apache.hadoop.hbase.ipcHBase
SimpleByteRangeA read only version of the ByteRange.Classorg.apache.hadoop.hbase.utilHBase
SimpleMutableByteRangeA basic mutable ByteRange implementation.Classorg.apache.hadoop.hbase.utilHBase
SimplePositionedByteRange support and it is a readonly version.Classorg.apache.hadoop.hbase.utilHBase
SimplePositionedMutableByteRange position support and it is a mutable version.Classorg.apache.hadoop.hbase.utilHBase
SimpleTotalOrderPartitionerA partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.Classorg.apache.hadoop.hbase.mapreduceHBase
SingleColumnValueExcludeFilterA Filter that checks a single column value, but does not emit the tested column.Classorg.apache.hadoop.hbase.filterHBase
SingleColumnValueFilterThis filter is used to filter cells based on value.Classorg.apache.hadoop.hbase.filterHBase
SkipFilterA wrapper filter that filters an entire row if any of the Cell checks do For example, if all columns in a row represent weights of different things,Classorg.apache.hadoop.hbase.filterHBase
SnapshotCreationExceptionThrown when a snapshot could not be created due to a server-side error when taking the snapshot.Classorg.apache.hadoop.hbase.snapshotHBase
SnapshotDoesNotExistExceptionThrown when the server is looking for a snapshot but can't find the snapshot on the filesystemSee Also:Serialized FormClassorg.apache.hadoop.hbase.snapshotHBase
SnapshotExistsExceptionThrown when a snapshot exists but should notSee Also:Serialized FormClassorg.apache.hadoop.hbase.snapshotHBase
SnapshotInfoTool for dumping snapshot information.Classorg.apache.hadoop.hbase.snapshotHBase
StoppedRpcClientExceptionClassorg.apache.hadoop.hbase.ipcHBase
Struct Struct is a simple DataType for implementing "compound rowkey" and "compound qualifier" schema design strategies.Classorg.apache.hadoop.hbase.typesHBase
StructBuilderA helper for building Struct instances.Classorg.apache.hadoop.hbase.typesHBase
StructIteratorAn Iterator over encoded Struct members.Classorg.apache.hadoop.hbase.typesHBase
SubstringComparatorThis comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.Classorg.apache.hadoop.hbase.filterHBase
SweeperThe sweep tool.Classorg.apache.hadoop.hbase.mob.mapreduceHBase
TableUsed to communicate with a single HBase table.Interfaceorg.apache.hadoop.hbase.clientHBase
TableExistsExceptionThrown when a table exists but should notSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
TableInfoMissingExceptionFailed to find .Classorg.apache.hadoop.hbaseHBase
TableInputFormatConvert HBase tabular data into a format that is consumable by Map/Reduce.Classorg.apache.hadoop.hbase.mapredHBase
TableInputFormatConvert HBase tabular data into a format that is consumable by Map/Reduce.Classorg.apache.hadoop.hbase.mapreduceHBase
TableInputFormatBaseA Base for TableInputFormats.Classorg.apache.hadoop.hbase.mapredHBase
TableInputFormatBaseA base for TableInputFormats.Classorg.apache.hadoop.hbase.mapreduceHBase
TableMapScan an HBase table to sort by a specified sort column.Interfaceorg.apache.hadoop.hbase.mapredHBase
TableMapperClassorg.apache.hadoop.hbase.mapreduceHBase
TableMapReduceUtilClassorg.apache.hadoop.hbase.mapredHBase
TableMapReduceUtilClassorg.apache.hadoop.hbase.mapreduceHBase
TableNameImmutable POJO class for representing a table name.Classorg.apache.hadoop.hbaseHBase
TableNotDisabledExceptionThrown if a table should be offline but is notSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
TableNotEnabledExceptionThrown if a table should be enabled but is notSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
TableNotFoundExceptionThrown when a table can not be locatedSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase
TableOutputCommitterSmall committer class that does not do anything.Classorg.apache.hadoop.hbase.mapreduceHBase
TableOutputFormatClassorg.apache.hadoop.hbase.mapredHBase
TableOutputFormatConvert Map/Reduce output and write it to an HBase table.Classorg.apache.hadoop.hbase.mapreduceHBase
TablePartiallyOpenExceptionThrown if a table should be online/offline but is partially openSee Also:Serialized FormClassorg.apache.hadoop.hbase.snapshotHBase
TableRecordReaderClassorg.apache.hadoop.hbase.mapredHBase
TableRecordReaderClassorg.apache.hadoop.hbase.mapreduceHBase
TableRecordReaderImplClassorg.apache.hadoop.hbase.mapredHBase
TableRecordReaderImplClassorg.apache.hadoop.hbase.mapreduceHBase
TableReduceInterfaceorg.apache.hadoop.hbase.mapredHBase
TableReducer value input/output classes.Classorg.apache.hadoop.hbase.mapreduceHBase
TableSnapshotInputFormatTableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.Classorg.apache.hadoop.hbase.mapredHBase
TableSnapshotInputFormatTableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.Classorg.apache.hadoop.hbase.mapreduceHBase
TableSnapshotScannerA Scanner which performs a scan over snapshot files.Classorg.apache.hadoop.hbase.clientHBase
TableSplitClassorg.apache.hadoop.hbase.mapredHBase
TableSplitA table split corresponds to a key range (low, high) and an optional scanner.Classorg.apache.hadoop.hbase.mapreduceHBase
TerminatedWrapperWraps an existing DataType implementation as a terminated version of itself.Classorg.apache.hadoop.hbase.typesHBase
TextSortReducerEmits Sorted KeyValues.Classorg.apache.hadoop.hbase.mapreduceHBase
ThrottleTypeDescribe the Throttle Type.Classorg.apache.hadoop.hbase.quotasHBase
ThrottlingExceptionDescribe the throttling result.Classorg.apache.hadoop.hbase.quotasHBase
ThrottlingException .TypeClassorg.apache.hadoop.hbase.quotas.ThrottlingExceptionHBase
TimeoutExceptionException for timeout of a task.Classorg.apache.hadoop.hbase.errorhandlingHBase
TimeRangeRepresents an interval of version timestamps.Classorg.apache.hadoop.hbase.ioHBase
TimestampsFilterFilter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).Classorg.apache.hadoop.hbase.filterHBase
TsvImporterMapperWrite table content out to files in hdfs.Classorg.apache.hadoop.hbase.mapreduceHBase
TsvImporterTextMapperWrite table content out to map output files.Classorg.apache.hadoop.hbase.mapreduceHBase
Union2The Union family of DataTypes encode one of a fixed set of Objects.Classorg.apache.hadoop.hbase.typesHBase
Union3The Union family of DataTypes encode one of a fixed collection of Objects.Classorg.apache.hadoop.hbase.typesHBase
Union4The Union family of DataTypes encode one of a fixed collection of Objects.Classorg.apache.hadoop.hbase.typesHBase
UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving.Classorg.apache.hadoop.hbase.exceptionsHBase
UnknownRegionExceptionThrown when we are asked to operate on a region we know nothing about.Classorg.apache.hadoop.hbaseHBase
UnknownScannerExceptionThrown if a region server is passed an unknown scanner id.Classorg.apache.hadoop.hbaseHBase
UnknownSnapshotExceptionException thrown when we get a request for a snapshot we don't recognize.Classorg.apache.hadoop.hbase.snapshotHBase
UnmodifyableHTableDescriptorRead-only table descriptor.Classorg.apache.hadoop.hbase.clientHBase
UnsupportedCellCodecExceptionClassorg.apache.hadoop.hbase.ipcHBase
UnsupportedCompressionCodecExceptionClassorg.apache.hadoop.hbase.ipcHBase
UserWrapper to abstract out usage of user and group information in HBase.Classorg.apache.hadoop.hbase.securityHBase
ValueFilterThis filter is used to filter based on column value.Classorg.apache.hadoop.hbase.filterHBase
VersionInfoThis class finds the package info for hbase and the VersionAnnotation information.Classorg.apache.hadoop.hbase.utilHBase
VisibilityExpressionResolverInterface to convert visibility expressions into Tags for storing along with Cells in HFiles.Interfaceorg.apache.hadoop.hbase.mapreduceHBase
WALInputFormatSimple InputFormat for WAL files.Classorg.apache.hadoop.hbase.mapreduceHBase
WALPlayerA tool to replay WAL files as a M/R job.Classorg.apache.hadoop.hbase.mapreduceHBase
WhileMatchFilterA wrapper filter that returns true from filterAllRemaining() as soon as the wrapped filters Filter.Classorg.apache.hadoop.hbase.filterHBase
WrongRegionExceptionThrown when a request contains a key which is not part of this regionSee Also:Serialized FormClassorg.apache.hadoop.hbase.regionserverHBase
WrongRowIOExceptionClassorg.apache.hadoop.hbase.clientHBase
WrongVersionExceptionClassorg.apache.hadoop.hbase.ipcHBase
ZooKeeperConnectionExceptionThrown if the client can't connect to zookeeperSee Also:Serialized FormClassorg.apache.hadoop.hbaseHBase