Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in off
heap/ on heap ByteBuffer |
CacheEvictionStats |
CacheEvictionStatsBuilder |
CallDroppedException
Returned to the clients when their request was discarded due to server being overloaded.
|
CatalogReplicaMode
There are two modes with catalog replica support.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
Cell.Type
The valid types for user to build the cell.
|
CellBuilder
Use
CellBuilderFactory to get CellBuilder instance. |
CellBuilderType
Used by
CellBuilderFactory and ExtendedCellBuilderFactory . |
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
CellComparatorImpl
Compare two HBase cells.
|
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClusterId
The identifier for this cluster.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
ClusterMetricsBuilder |
CompareOperator
Generic set of comparison operators.
|
CompatibilityFactory
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
|
CompatibilitySingletonFactory.SingletonStorage |
CompoundConfiguration
Do a shallow merge of multiple KV configuration pools.
|
CompoundConfiguration.ImmutableConfigMap |
CoordinatedStateManager
Implementations of this interface will keep and return to clients implementations of classes
providing API to execute coordinated operations.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
Coprocessor.State
Lifecycle state of a given coprocessor instance.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
ExtendedCell
Extension to
Cell with server side required functions. |
ExtendedCellBuilder
For internal purpose.
|
ExtendedCellBuilderImpl |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HBaseServerException
Base class for exceptions thrown by an HBase server.
|
HColumnDescriptor
Deprecated.
|
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HDFSBlocksDistribution.HostAndWeight
Stores the hostname and weight for that hostname.
|
HDFSBlocksDistribution.Visitor
Implementations 'visit' hostAndWeight.
|
HealthChecker
A utility for executing an external script that checks the health of the node.
|
HealthChecker.HealthCheckerExitStatus |
HealthReport
The Class HealthReport containing information about health of the node.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly
used in places where we need to compare two cells.
|
KeyValue.KVComparator
Deprecated.
: Use
CellComparatorImpl . Deprecated for hbase 2.0, remove for hbase 3.0. |
KeyValue.MetaComparator
Deprecated.
:
MetaCellComparator.META_COMPARATOR to be used. Deprecated for hbase 2.0,
remove for hbase 3.0. |
KeyValue.SamePrefixComparator
Avoids redundant comparisons for better performance.
|
KeyValue.Type
Key type.
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
MetaCellComparator |
MetaCellComparator.Compare |
MetaCellComparator.SearchDelimiter |
MetaCellComparator.SearchDelimiterInReverse |
MetaRegionLocationCache.ZNodeOpType |
MetaTableAccessor.CollectingVisitor
A
MetaTableAccessor.Visitor that collects content out of passed Result . |
MetaTableAccessor.DefaultVisitorBase
A Visitor that skips offline regions and split parents
|
MetaTableAccessor.QueryType |
MetaTableAccessor.ReplicationBarrierResult |
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceDescriptor.Builder |
NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
|
PrivateCellUtil.EmptyByteBufferExtendedCell
These cells are used in reseeks/seeks to improve the read performance.
|
PrivateCellUtil.EmptyCell
These cells are used in reseeks/seeks to improve the read performance.
|
PrivateCellUtil.FirstOnRowByteBufferExtendedCell |
PrivateCellUtil.FirstOnRowCell |
PrivateCellUtil.FirstOnRowColByteBufferExtendedCell |
PrivateCellUtil.FirstOnRowColCell |
PrivateCellUtil.LastOnRowByteBufferExtendedCell |
PrivateCellUtil.LastOnRowCell |
PrivateCellUtil.TagRewriteByteBufferExtendedCell |
PrivateCellUtil.TagRewriteCell
This can be used when a Cell has to change with addition/removal of one or more tags.
|
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
RawCellBuilder
Allows creating a cell with
Tag An instance of this type can be acquired by using
RegionCoprocessorEnvironment#getCellBuilder (for prod code) and RawCellBuilderFactory
(for unit tests). |
RegionLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
RegionMetrics
instead. |
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the same range. |
RegionMetrics
Encapsulates per-region load metrics.
|
RegionMetricsBuilder |
RetryImmediatelyException |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ServerMetrics
instead. |
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerMetricsBuilder |
ServerName
Name of a particular incarnation of an HBase Server.
|
ServerTask
Information about active monitored server tasks
|
ServerTask.State
Task state
|
ServerTaskBuilder
Builder for information about active monitored server tasks
|
Size
It is used to represent the size with different units.
|
Size.Unit |
SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
|
SplitLogTask
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
TagBuilder
Builder implementation to create
Tag Call setTagValue(byte[]) method to create
ArrayBackedTag |
UserMetrics
Encapsulates per-user load metrics.
|
UserMetrics.ClientMetrics |
UserMetricsBuilder |
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
Stoppable
Implementers are Stoppable.
|
ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
CacheEvictionStats |
CatalogReplicaMode
There are two modes with catalog replica support.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
ClusterStatus
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterMetrics
instead. |
CompareOperator
Generic set of comparison operators.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
ExtendedCell
Extension to
Cell with server side required functions. |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HColumnDescriptor
Deprecated.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
MasterNotRunningException
Thrown if the master is not running
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
NamespaceDescriptor
Namespace POJO class.
|
NamespaceNotFoundException
Thrown when a namespace can not be located
|
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
RegionException
Thrown when something happens related to region handling.
|
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the same range. |
RegionMetrics
Encapsulates per-region load metrics.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableExistsException
Thrown when a table exists but should not.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table cannot be located.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
ExtendedCellBuilder
For internal purpose.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
Class and Description |
---|
CoordinatedStateManager
Implementations of this interface will keep and return to clients implementations of classes
providing API to execute coordinated operations.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
SplitLogTask
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
ClusterMetrics
Metrics information on the HBase cluster.
|
CompareOperator
Generic set of comparison operators.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
Coprocessor.State
Lifecycle state of a given coprocessor instance.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it holds mutations
for hbase:meta table.
|
NamespaceDescriptor
Namespace POJO class.
|
RawCellBuilder
Allows creating a cell with
Tag An instance of this type can be acquired by using
RegionCoprocessorEnvironment#getCellBuilder (for prod code) and RawCellBuilderFactory
(for unit tests). |
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellBuilder
Use
CellBuilderFactory to get CellBuilder instance. |
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not serving.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
Cell
The unit of storage in HBase consisting of the following fields:
|
Cell.Type
The valid types for user to build the cell.
|
CompareOperator
Generic set of comparison operators.
|
ExtendedCell
Extension to
Cell with server side required functions. |
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
Size
It is used to represent the size with different units.
|
Size.Unit |
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
RegionMetrics
Encapsulates per-region load metrics.
|
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
UserMetrics.ClientMetrics |
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
ByteBufferKeyOnlyKeyValue
This is a key only Cell implementation which is identical to
KeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and
offheap). |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
ExtendedCell
Extension to
Cell with server side required functions. |
KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly
used in places where we need to compare two cells.
|
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
Class and Description |
---|
ByteBufferKeyOnlyKeyValue
This is a key only Cell implementation which is identical to
KeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and
offheap). |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
CallDroppedException
Returned to the clients when their request was discarded due to server being overloaded.
|
CallQueueTooBigException
Returned to clients when their request was dropped because the call queue was too big to accept a
new call.
|
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
KeyValue
An HBase Key/Value.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClockOutOfSyncException
This exception is thrown by the master when a region server clock skew is too high.
|
ClusterId
The identifier for this cluster.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
CoprocessorEnvironment
Coprocessor environment state.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
LocalHBaseCluster
This class creates a single process HBase cluster.
|
MasterNotRunningException
Thrown if the master is not running
|
MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it holds mutations
for hbase:meta table.
|
NamespaceDescriptor
Namespace POJO 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.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
ServiceNotRunningException |
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotDisabledException
Thrown if a table should be offline but is not.
|
TableNotFoundException
Thrown when a table cannot be located.
|
UnknownRegionException
Thrown when we are asked to operate on a region we know nothing about.
|
YouAreDeadException
This exception is thrown by the master when a region server reports and is already being
processed as dead.
|
ZKNamespaceManager
Class servers two purposes: 1.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
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.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
UnknownRegionException
Thrown when we are asked to operate on a region we know nothing about.
|
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
RegionMetrics
Encapsulates per-region load metrics.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
RegionMetrics
Encapsulates per-region load metrics.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Size
It is used to represent the size with different units.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
ServerMetrics
This class is used for exporting current state of load on a RegionServer.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Size
It is used to represent the size with different units.
|
Class and Description |
---|
MetaTableAccessor.CloseableVisitor
Implementations 'visit' a catalog table row but with close() at the end.
|
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
RegionLocations
Container for holding a list of
HRegionLocation 's that correspond to the same range. |
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
Class and Description |
---|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
MetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
Cell
The unit of storage in HBase consisting of the following fields:
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
NamespaceDescriptor
Namespace POJO class.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
Class and Description |
---|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
NamespaceDescriptor
Namespace POJO class.
|
RegionStateListener
The listener interface for receiving region state events.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in off
heap/ on heap ByteBuffer |
CacheEvictionStats |
CacheEvictionStatsBuilder |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
CellScannable
Implementer can return a CellScanner over its Cell content.
|
CellScanner
An interface for iterating through a sequence of cells.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
CompareOperator
Generic set of comparison operators.
|
CoordinatedStateManager
Implementations of this interface will keep and return to clients implementations of classes
providing API to execute coordinated operations.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
ExtendedCell
Extension to
Cell with server side required functions. |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HealthCheckChore
The Class HealthCheckChore for running health checker regularly.
|
KeepDeletedCells
Ways to keep cells marked for delete around.
|
KeyValue
An HBase Key/Value.
|
KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly
used in places where we need to compare two cells.
|
MemoryCompactionPolicy
Enum describing all possible memory compaction policies
|
MetaRegionLocationCache
A cache of meta region location metadata.
|
NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
|
NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not serving.
|
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
RawCellBuilder
Allows creating a cell with
Tag An instance of this type can be acquired by using
RegionCoprocessorEnvironment#getCellBuilder (for prod code) and RawCellBuilderFactory
(for unit tests). |
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
KeepDeletedCells
Ways to keep cells marked for delete around.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
CoprocessorEnvironment
Coprocessor environment state.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
ExtendedCellBuilder
For internal purpose.
|
ScheduledChore
ScheduledChore is a task performed on a period in hbase.
|
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
CoordinatedStateManager
Implementations of this interface will keep and return to clients implementations of classes
providing API to execute coordinated operations.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
MetaTableAccessor.ReplicationBarrierResult |
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table cannot be located.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
Class and Description |
---|
ClusterMetrics
Metrics information on the HBase cluster.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
Class and Description |
---|
BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via
BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the
BaseConfigurable.setConf(Configuration) method |
Cell
The unit of storage in HBase consisting of the following fields:
|
CompareOperator
Generic set of comparison operators.
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
KeyValue
An HBase Key/Value.
|
MasterNotRunningException
Thrown if the master is not running
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableName
Immutable POJO class for representing a table name.
|
ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
|
Class and Description |
---|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
Stoppable
Implementers are Stoppable.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment
Coprocessor environment state.
|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
KeyValue.Type
Key type.
|
TableName
Immutable POJO class for representing a table name.
|
Tag
Tags are part of cells and helps to add metadata about them.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
HColumnDescriptor
Deprecated.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Cell
The unit of storage in HBase consisting of the following fields:
|
Cell.Type
The valid types for user to build the cell.
|
CompareOperator
Generic set of comparison operators.
|
ExtendedCellBuilder
For internal purpose.
|
HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
KeepDeletedCells
Ways to keep cells marked for delete around.
|
NamespaceDescriptor
Namespace POJO class.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
CacheEvictionStats |
ClusterMetrics
Metrics information on the HBase cluster.
|
ClusterMetrics.Option
Kinds of ClusterMetrics
|
CompareOperator
Generic set of comparison operators.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
HTableDescriptor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
TableDescriptorBuilder to build HTableDescriptor . |
NamespaceDescriptor
Namespace POJO class.
|
NamespaceNotFoundException
Thrown when a namespace can not be located
|
RegionMetrics
Encapsulates per-region load metrics.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableExistsException
Thrown when a table exists but should not.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table cannot be located.
|
Class and Description |
---|
Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
TableNotFoundException
Thrown when a table cannot be located.
|
Class and Description |
---|
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
Cell
The unit of storage in HBase consisting of the following fields:
|
CellComparator
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
|
ChoreService
ChoreService is a service that can be used to schedule instances of
ScheduledChore to run
periodically while sharing threads. |
ClusterId
The identifier for this cluster.
|
ClusterMetrics
Metrics information on the HBase cluster.
|
ExtendedCell
Extension to
Cell with server side required functions. |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
|
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. use
RegionInfoBuilder to build RegionInfo . |
MasterNotRunningException
Thrown if the master is not running
|
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
TableDescriptors
Get, remove and modify table descriptors.
|
TableName
Immutable POJO class for representing a table name.
|
ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
ServerName
Name of a particular incarnation of an HBase Server.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
Cell
The unit of storage in HBase consisting of the following fields:
|
CellScanner
An interface for iterating through a sequence of cells.
|
ServerName
Name of a particular incarnation of an HBase Server.
|
TableName
Immutable POJO class for representing a table name.
|
Class and Description |
---|
Abortable
Interface to support the aborting of a given server or client.
|
ClusterId
The identifier for this cluster.
|
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
ServerName
Name of a particular incarnation of an HBase Server.
|
Stoppable
Implementers are Stoppable.
|
ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
|
Class and Description |
---|
TableName
Immutable POJO class for representing a table name.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.