Package | Description |
---|---|
org.apache.hadoop.hbase.backup.example | |
org.apache.hadoop.hbase.client.coprocessor |
Provides client classes for invoking Coprocessor RPC protocols
|
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.master.cleaner | |
org.apache.hadoop.hbase.master.snapshot | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.compactions | |
org.apache.hadoop.hbase.regionserver.snapshot | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication.master | |
org.apache.hadoop.hbase.rest.filter | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility |
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 |
---|---|
class |
RowProcessorClient
Convenience class that is used to make RowProcessorEndpoint invocations.
|
Modifier and Type | Class and Description |
---|---|
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 |
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
HRegion.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>, long, long) and Coprocessor endpoints. |
class |
BaseWALObserver
An abstract class that implements WALObserver.
|
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 |
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 |
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. |
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.
|
interface |
RpcServerInterface
RpcServer Interface.
|
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 |
---|---|
static class |
ClusterStatusPublisher.MulticastPublisher |
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 hlog 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 |
BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
Base class for RowProcessor with some default implementations.
|
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. |
class |
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
HRegion . |
class |
RegionServerCoprocessorHost |
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 for
a region server. |
class |
SimpleRpcSchedulerFactory
Constructs a
SimpleRpcScheduler . |
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 | Class and Description |
---|---|
class |
CompactionRequest
This class holds all logical details necessary to run a compaction.
|
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 |
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.
|
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 |
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
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.