Package | Description |
---|---|
org.apache.hadoop.hbase.http.lib |
This package provides user-selectable (via configuration) classes that add
functionality to the web UI.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Abortable
Interface to support the aborting of a given server or client.
|
interface |
Coprocessor
Coprocessor interface.
|
interface |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
interface |
SettableSequenceId
Using this Interface one can mark a Cell as Sequence stampable.
|
interface |
SettableTimestamp
Using this Interface one can mark a Cell as timestamp changeable.
|
interface |
Stoppable
Implementers are Stoppable.
|
Modifier and Type | Class and Description |
---|---|
class |
LongTermArchivingHFileCleaner
BaseHFileCleanerDelegate that only cleans HFiles that don't belong to a table that is
currently being archived. |
Modifier and Type | Class and Description |
---|---|
(package private) class |
ClusterStatusListener.MulticastListener
An implementation using a multicast message between the master & the client.
|
Modifier and Type | Class and Description |
---|---|
class |
RowProcessorClient
Convenience class that is used to make RowProcessorEndpoint invocations.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseDecoder
TODO javadoc
|
class |
BaseEncoder
TODO javadoc
|
class |
CellCodec
Basic Cell codec that just writes out all the individual elements of a Cell.
|
class |
CellCodecWithTags
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
|
interface |
Codec
Encoder/Decoder for Cell.
|
class |
KeyValueCodec
Codec that does KeyValue version 1 serialization.
|
class |
KeyValueCodecWithTags
Codec that does KeyValue version 1 serialization with serializing tags also.
|
class |
MessageCodec
Codec that just writes out Cell as a protobuf Cell Message.
|
Modifier and Type | Class and Description |
---|---|
class |
ZkCoordinatedStateManager
ZooKeeper-based implementation of
CoordinatedStateManager . |
Modifier and Type | Class and Description |
---|---|
class |
BaseMasterAndRegionObserver |
class |
BaseMasterObserver |
class |
BaseRegionObserver
An abstract class that implements RegionObserver.
|
class |
BaseRegionServerObserver
An abstract class that implements RegionServerObserver.
|
class |
BaseRowProcessorEndpoint<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
This class demonstrates how to implement atomic read-modify-writes
using
Region.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>) and Coprocessor endpoints. |
class |
BaseWALObserver
An abstract class that implements WALObserver.
|
interface |
BulkLoadObserver
Coprocessors implement this interface to observe and mediate bulk load operations.
|
class |
CoprocessorHost<E extends CoprocessorEnvironment>
Provides the common setup framework and runtime services for coprocessor
invocation from HBase services.
|
interface |
CoprocessorService
Coprocessor endpoints providing protobuf services should implement this
interface and return the
Service instance via CoprocessorService.getService() . |
interface |
EndpointObserver
Coprocessors implement this interface to observe and mediate endpoint invocations
on a region.
|
interface |
MasterCoprocessorEnvironment |
interface |
MasterObserver
Defines coprocessor hooks for interacting with operations on the
HMaster process. |
class |
MultiRowMutationEndpoint
This class demonstrates how to implement atomic multi row transactions using
HRegion.mutateRowsWithLocks(java.util.Collection, java.util.Collection)
and Coprocessor endpoints. |
class |
ObserverContext<E extends CoprocessorEnvironment>
Carries the execution state for a given invocation of an Observer coprocessor
(
RegionObserver , MasterObserver , or WALObserver )
method. |
interface |
RegionCoprocessorEnvironment |
interface |
RegionObserver
Coprocessors implement this interface to observe and mediate client actions
on the region.
|
interface |
SingletonCoprocessorService
Coprocessor endpoints registered once per server and providing protobuf services should implement
this interface and return the
Service instance via SingletonCoprocessorService.getService() . |
interface |
WALCoprocessorEnvironment |
interface |
WALObserver
It's provided to have a way for coprocessors to observe, rewrite,
or skip WALEdits as they are being written to the WAL.
|
Modifier and Type | Class and Description |
---|---|
class |
ClickjackingPreventionFilter |
static class |
HttpServer.QuotingInputFilter
A Servlet input filter that quotes all HTML active characters in the
parameter names and values.
|
class |
NoCacheFilter |
Modifier and Type | Class and Description |
---|---|
class |
ConfServlet
A servlet to print out the running configuration data.
|
Modifier and Type | Class and Description |
---|---|
class |
StaticUserWebFilter
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who)
so that the web UI is usable for a secure cluster without authentication.
|
static class |
StaticUserWebFilter.StaticUserFilter |
Modifier and Type | Class and Description |
---|---|
static class |
LogLevel.Servlet
A servlet implementation
|
Modifier and Type | Class and Description |
---|---|
class |
HFilePrettyPrinter
Implements pretty-printing functionality for
HFile s. |
class |
InclusiveCombinedBlockCache |
Modifier and Type | Class and Description |
---|---|
class |
AsyncRpcClient
Netty client for the requests and responses
|
class |
BalancedQueueRpcExecutor
An
RpcExecutor that will balance requests evenly across all its queues, but still remains
efficient with a single queue via an inlinable queue balancing mechanism. |
class |
CallRunner
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler . |
interface |
PriorityFunction
Function to figure priority of incoming request.
|
class |
RpcScheduler
An interface for RPC request scheduling algorithm.
|
class |
RpcServer
An RPC server that hosts protobuf described Services.
|
class |
RpcServer.Call
Datastructure that holds all necessary to a method invocation and then afterward, carries
the result.
|
interface |
RpcServerInterface |
class |
RWQueueRpcExecutor
RPC Executor that uses different queues for reads and writes.
|
class |
SimpleRpcScheduler
A scheduler that maintains isolated handler pools for general,
high-priority, and replication requests.
|
Modifier and Type | Class and Description |
---|---|
class |
Driver
Driver for hbase mapreduce jobs.
|
Modifier and Type | Class and Description |
---|---|
class |
Driver
Driver for hbase mapreduce jobs.
|
class |
MultiTableSnapshotInputFormatImpl
Shared implementation of mapreduce code over multiple table snapshots.
|
Modifier and Type | Class and Description |
---|---|
static class |
ClusterStatusPublisher.MulticastPublisher |
class |
HMaster
HMaster is the "master server" for HBase.
|
class |
RegionPlan
Stores the plan for the move of an individual region.
|
Modifier and Type | Class and Description |
---|---|
class |
FavoredNodeLoadBalancer
An implementation of the
LoadBalancer
that assigns favored nodes for each region. |
class |
SimpleLoadBalancer
Makes decisions about the placement and movement of Regions across
RegionServers.
|
class |
StochasticLoadBalancer
This is a best effort load balancer.
|
Modifier and Type | Class and Description |
---|---|
class |
HFileLinkCleaner
HFileLink cleaner that determines if a hfile should be deleted.
|
class |
TimeToLiveHFileCleaner
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.
|
class |
TimeToLiveLogCleaner
Log cleaner that uses the timestamp of the wal to determine if it should
be deleted.
|
Modifier and Type | Class and Description |
---|---|
class |
SnapshotHFileCleaner
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
|
class |
SnapshotLogCleaner
Implementation of a log cleaner that checks if a log is still used by
snapshots of HBase tables.
|
class |
SnapshotManager
This class manages the procedure of taking and restoring snapshots.
|
Modifier and Type | Class and Description |
---|---|
class |
MasterFlushTableProcedureManager |
class |
RegionServerFlushTableProcedureManager
This manager class handles flushing of the regions for table on a
HRegionServer . |
Modifier and Type | Class and Description |
---|---|
class |
ProcedureWALPrettyPrinter
ProcedureWALPrettyPrinter prints the contents of a given ProcedureWAL file
|
Modifier and Type | Class and Description |
---|---|
class |
BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
Base class for RowProcessor with some default implementations.
|
class |
CompactionTool |
class |
ConstantSizeRegionSplitPolicy
A
RegionSplitPolicy implementation which splits a region
as soon as any of its store files exceeds a maximum configurable
size. |
class |
DefaultStoreEngine
Default StoreEngine creates the default compactor, policy, and store file manager, or
their derivatives.
|
class |
DisabledRegionSplitPolicy
A
RegionSplitPolicy that disables region splits. |
interface |
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get
the favored nodes information for regions.
|
class |
FlushLargeStoresPolicy
A
FlushPolicy that only flushes store larger a given threshold. |
class |
FlushPolicyFactory
The class that creates a flush policy from a conf and HTableDescriptor.
|
class |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
class |
InternalScan
Special scanner, currently used for increment operations to
allow additional server-side arguments for Scan operations.
|
class |
NoLimitScannerContext
This is a special
ScannerContext subclass that is designed to be used globally when
limits should not be enforced during invocations of InternalScanner.next(java.util.List)
or InternalScanner.next(java.util.List) . |
interface |
OnlineRegions
Interface to Map of online regions.
|
interface |
Region
Regions store data for a certain region of a table.
|
class |
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
Region . |
interface |
RegionMergeTransaction
Executes region merge as a "transaction".
|
class |
RegionMergeTransactionFactory
A factory for creating RegionMergeTransactions, which execute region split as a "transaction".
|
interface |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
class |
RegionServerCoprocessorHost |
interface |
RegionServerServices
Services provided by
HRegionServer |
class |
RegionSplitPolicy
A split policy determines when a region should be split.
|
interface |
RowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
interface |
RpcSchedulerFactory
A factory class that constructs an
RpcScheduler . |
class |
ScannerContext
ScannerContext instances encapsulate limit tracking AND progress towards those limits during
invocations of
InternalScanner.next(java.util.List) and
InternalScanner.next(java.util.List) . |
class |
ScanType
Enum to distinguish general scan types.
|
class |
SimpleRpcSchedulerFactory
Constructs a
SimpleRpcScheduler . |
interface |
SplitTransaction
Executes region split as a "transaction".
|
class |
SplitTransactionFactory
A factory for creating SplitTransactions, which execute region split as a "transaction".
|
interface |
Store
Interface for objects that hold a column family in a Region.
|
class |
StoreFile
A Store data file.
|
class |
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
class |
StripeStoreEngine
The storage engine that implements the stripe-based store/compaction scheme.
|
Modifier and Type | Field and Description |
---|---|
protected static String |
HRegionServer.MASTER_HOSTNAME_KEY |
(package private) static String |
HRegionServer.RS_HOSTNAME_KEY |
Modifier and Type | Class and Description |
---|---|
class |
CompactionRequest
This class holds all logical details necessary to run a compaction.
|
interface |
CompactionThroughputController
A utility that constrains the total throughput of one or more simultaneous flows (compactions) by
sleeping when necessary.
|
class |
CompactionThroughputControllerFactory |
class |
NoLimitCompactionThroughputController
A dummy CompactionThroughputController that does nothing.
|
class |
PressureAwareCompactionThroughputController
A throughput controller which uses the follow schema to limit throughput
If compaction pressure is greater than 1.0, no limitation.
In off peak hours, use a fixed throughput limitation
"hbase.hstore.compaction.throughput.offpeak"
In normal hours, the max throughput is tune between
"hbase.hstore.compaction.throughput.lower.bound" and
"hbase.hstore.compaction.throughput.higher.bound", using the formula "lower +
(higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]
|
Modifier and Type | Class and Description |
---|---|
class |
RegionServerSnapshotManager
This manager class handles the work dealing with snapshots for a
HRegionServer . |
Modifier and Type | Class and Description |
---|---|
class |
CompressionContext
Context that holds the various dictionaries for compression in WAL.
|
class |
HLogKey
Deprecated.
use WALKey
|
class |
HLogPrettyPrinter
Deprecated.
use the "hbase wal" command
|
class |
ProtobufLogReader
A Protobuf based WAL has the following structure:
|
class |
ProtobufLogWriter
Writer for protobuf-based WAL.
|
class |
ReaderBase |
class |
SecureProtobufLogReader |
class |
SecureProtobufLogWriter |
class |
SequenceFileLogReader |
class |
WALCellCodec
Compression in this class is lifted off Compressor/KeyValueCompression.
|
class |
WALEdit
WALEdit: Used in HBase's transaction log (WAL) to represent
the collection of edits (KeyValue objects) corresponding to a
single transaction.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseReplicationEndpoint
A Base implementation for
ReplicationEndpoint s. |
class |
BaseWALEntryFilter
A base class WALEntryFilter implementations.
|
class |
ChainWALEntryFilter
A
WALEntryFilter which contains multiple filters and applies them
in chain order |
interface |
ReplicationEndpoint
ReplicationEndpoint is a plugin which implements replication
to other HBase clusters, or other systems.
|
static class |
ReplicationEndpoint.Context |
static class |
ReplicationEndpoint.ReplicateContext
A context for
ReplicationEndpoint.replicate(ReplicateContext) method. |
interface |
ReplicationPeer
ReplicationPeer manages enabled / disabled state for the peer.
|
static class |
ReplicationPeer.PeerState
State of the peer, whether it is enabled or not
|
interface |
WALEntryFilter
A Filter for WAL entries before being sent over to replication.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicationLogCleaner
Implementation of a log cleaner that checks if a log is still scheduled for
replication before deleting it when its TTL is over.
|
Modifier and Type | Class and Description |
---|---|
class |
MetricsSource
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
|
Modifier and Type | Class and Description |
---|---|
class |
RESTServer
Main class for launching REST gateway as a servlet hosted by Jetty.
|
Modifier and Type | Class and Description |
---|---|
class |
GzipFilter |
Modifier and Type | Class and Description |
---|---|
class |
AccessController
Provides basic authorization checks for data access and administrative
operations.
|
Modifier and Type | Class and Description |
---|---|
class |
VisibilityController
Coprocessor that has both the MasterObserver and RegionObserver implemented that supports in
visibility labels
|
Modifier and Type | Class and Description |
---|---|
class |
ThriftServer
ThriftServer- this class starts up a Thrift server which implements the
Hbase API specified in the Hbase.thrift IDL file.
|
Modifier and Type | Class and Description |
---|---|
class |
ThriftServer
ThriftServer - this class starts up a Thrift server which implements the HBase API specified in the
HbaseClient.thrift IDL file.
|
Modifier and Type | Class and Description |
---|---|
class |
CompressionTest
Compression validation test.
|
class |
HBaseFsck
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
|
class |
MapreduceDependencyClasspathTool
Generate a classpath string containing any jars required by mapreduce jobs.
|
class |
Merge
Utility that can merge any two regions in the same table: adjacent,
overlapping or disjoint.
|
Modifier and Type | Class and Description |
---|---|
class |
OfflineMetaRepair
This code is used to rebuild meta off line from file system data.
|
Modifier and Type | Class and Description |
---|---|
class |
WALKey
A Key for an entry in the change log.
|
class |
WALPrettyPrinter
WALPrettyPrinter prints the contents of a given WAL with a variety of
options affecting formatting and extent of content.
|
Modifier and Type | Class and Description |
---|---|
class |
HQuorumPeer
HBase's version of ZooKeeper's QuorumPeer.
|
class |
ZKServerTool
Tool for reading ZooKeeper servers from HBase XML configuration and producing
a line-by-line list for use by bash scripts.
|
class |
ZooKeeperMainServer
Tool for running ZookeeperMain from HBase by reading a ZooKeeper server
from HBase XML configuration.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.