Class and Description |
---|
BloomType |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
Class and Description |
---|
HStoreFile
A Store data file.
|
Class and Description |
---|
BloomType |
HRegion
Regions store data for a certain region of a table.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
Class and Description |
---|
RowProcessor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use
Coprocessors instead.
|
Class and Description |
---|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
SplitLogWorker
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 SplitWALRemoteProcedure
|
SplitLogWorker.TaskExecutor
Deprecated.
Objects implementing this interface actually do the task that has been acquired by a
SplitLogWorker . |
Class and Description |
---|
FlushLifeCycleTracker
Used to track flush execution.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
OnlineRegions
Provides read-only access to the Regions presently online on the current RegionServer
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
Region.Operation
Operation enum is used in
Region.startRegionOperation() and elsewhere to provide context
for various checks. |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
RowProcessor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use
Coprocessors instead.
|
ScanOptions
This class gives you the ability to change the max versions and TTL options before opening a
scanner for a Store.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreFile
An interface to describe a store data file.
|
StoreFileReader
Reader for a StoreFile.
|
Class and Description |
---|
FlushLifeCycleTracker
Used to track flush execution.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
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) . |
ScanOptions
This class gives you the ability to change the max versions and TTL options before opening a
scanner for a Store.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreFile
An interface to describe a store data file.
|
Class and Description |
---|
StoreFileReader
Reader for a StoreFile.
|
Class and Description |
---|
BloomType |
CellSink
A sink of cells that allows appending cells to the Writers that implement it.
|
Shipper
This interface denotes a scanner as one which can ship cells.
|
ShipperListener
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped() is called |
Class and Description |
---|
RSRpcServices
Implements the regionserver RPC services.
|
Class and Description |
---|
BloomType |
StoreFileWriter
A StoreFile writer.
|
Class and Description |
---|
AnnotationReadingPriorityFunction
Reads special method annotations and table names to figure a priority for use by QoS facility in
ipc; e.g: rpcs to hbase:meta get priority.
|
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get the favored nodes
information for regions.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
MutableOnlineRegions
Interface to Map of online regions.
|
OnlineRegions
Provides read-only access to the Regions presently online on the current RegionServer
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
RpcSchedulerFactory
A factory class that constructs an
RpcScheduler . |
RSRpcServices
Implements the regionserver RPC services.
|
Class and Description |
---|
HRegionFileSystem
View to an on-disk Region.
|
HStoreFile
A Store data file.
|
RegionSplitPolicy
A split policy determines when a Region should be split.
|
Class and Description |
---|
HRegion
Regions store data for a certain region of a table.
|
HRegion.FlushResult |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
Class and Description |
---|
BloomType |
CellSink
A sink of cells that allows appending cells to the Writers that implement it.
|
DefaultStoreEngine
Default StoreEngine creates the default compactor, policy, and store file manager, or their
derivatives.
|
DefaultStoreFlusher
Default implementation of StoreFlusher.
|
FlushLifeCycleTracker
Used to track flush execution.
|
HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
HStore
A Store holds a column family in a Region.
|
HStoreFile
A Store data file.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
MemStoreSnapshot
MemStoreSnapshot is a Context Object to hold details of the snapshot taken on a MemStore. |
StoreEngine
StoreEngine is a factory that can create the objects necessary for HStore to operate.
|
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
StoreFileWriter
A StoreFile writer.
|
StoreFlusher
Store flusher interface.
|
Class and Description |
---|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
HRegion
Regions store data for a certain region of a table.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
Class and Description |
---|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
MetricsRegionServer
Maintains regionserver statistics and publishes them through the metrics interfaces.
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
AbstractMemStore
An abstract class, which implements the behaviour shared by all concrete memstore instances.
|
AbstractMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files.
|
AbstractMultiFileWriter.WriterFactory |
BloomType |
BrokenStoreFileCleaner
This Chore, every time it runs, will clear the unsused HFiles in the data folder.
|
CellFlatMap
CellFlatMap stores a constant number of elements and is immutable after creation stage.
|
CellSet |
CellSink
A sink of cells that allows appending cells to the Writers that implement it.
|
ChangedReadersObserver
If set of MapFile.Readers in Store change, implementors are notified.
|
Chunk
A chunk of memory out of which allocations are sliced.
|
ChunkCreator
Does the management of memstoreLAB chunk creations.
|
ChunkCreator.ChunkType
Types of chunks, based on their sizes
|
ChunkCreator.MemStoreChunkPool
A pool of
Chunk instances. |
CompactedHFilesDischarger
A chore service that periodically cleans up the compacted files when there are no active readers
using those compacted files and also helps in clearing the block cache of these compacted file
entries.
|
CompactingMemStore
A memstore implementation which supports in-memory compaction.
|
CompactingMemStore.IndexType
Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge
are applied.
|
CompactionPipeline
The compaction pipeline of a
CompactingMemStore , is a FIFO queue of segments. |
CompactionTool.CompactionWorker
Class responsible to execute the Compaction on the specified path.
|
CompactSplit
Compact region on request and then run split if appropriate
|
CompactSplit.CompactionCompleteTracker |
CompositeImmutableSegment
The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the
interface of a single ImmutableSegments.
|
ConstantSizeRegionSplitPolicy
A
RegionSplitPolicy implementation which splits a region as soon as any of its store
files exceeds a maximum configurable size. |
CreateStoreFileWriterParams |
CSLMImmutableSegment
CSLMImmutableSegment is an abstract class that extends the API supported by a
Segment ,
and ImmutableSegment . |
DefaultHeapMemoryTuner.StepDirection |
DefaultStoreFlusher
Default implementation of StoreFlusher.
|
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get the favored nodes
information for regions.
|
FifoRpcSchedulerFactory
Factory to use when you want to use the
FifoRpcScheduler |
FlushLargeStoresPolicy
A
FlushPolicy that only flushes store larger a given threshold. |
FlushLifeCycleTracker
Used to track flush execution.
|
FlushPolicy
A flush policy determines the stores that need to be flushed when flushing a region.
|
FlushRequester
Request a flush.
|
FlushRequestListener
Listener which will get notified regarding flush requests of regions.
|
FlushType
Reasons we flush.
|
HeapMemoryManager
Manages tuning of Heap memory using
HeapMemoryTuner . |
HeapMemoryManager.HeapMemoryTuneObserver
Every class that wants to observe heap memory tune actions must implement this interface.
|
HeapMemoryManager.HeapMemoryTunerChore |
HeapMemoryManager.TunerContext
POJO to pass all the relevant information required to do the heap memory tuning.
|
HeapMemoryManager.TunerResult
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
|
HeapMemoryTuner
Makes the decision regarding proper sizing of the heap memory.
|
HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
|
HRegion
Regions store data for a certain region of a table.
|
HRegion.BatchOperation
Class that tracks the progress of a batch operations, accumulating status codes and tracking
the index at which processing is proceeding.
|
HRegion.BatchOperation.Visitor
Visitor interface for batch operations
|
HRegion.BulkLoadListener
Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post
processing of a given bulkload call
|
HRegion.FlushResult |
HRegion.FlushResult.Result |
HRegion.FlushResultImpl
Objects from this class are created when flushing to describe all the different states that
that method ends up in.
|
HRegion.ObservedExceptionsInBatch
A class that tracks exceptions that have been observed in one batch.
|
HRegion.PrepareFlushResult
A result object from prepare flush cache stage
|
HRegion.RowLockContext |
HRegion.RowLockImpl
Class used to represent a lock on a row.
|
HRegion.WriteState |
HRegionFileSystem
View to an on-disk Region.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
HRegionServer.MovedRegionInfo |
HRegionWALFileSystem
A Wrapper for the region FileSystem operations adding WAL specific operations
|
HStore
A Store holds a column family in a Region.
|
HStore.StoreFileWriterCreationTracker |
HStoreFile
A Store data file.
|
ImmutableSegment
ImmutableSegment is an abstract class that extends the API supported by a
Segment , and is
not needed for a MutableSegment . |
IncreasingToUpperBoundRegionSplitPolicy
Split size is the number of regions that are on this server that all are of the same table,
cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
|
InputStreamBlockDistribution
Computes the HDFSBlockDistribution for a file based on the underlying located blocks for an
HdfsDataInputStream reading that file.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
|
KeyValueHeap.KVScannerComparator |
KeyValueScanner
Scanner that returns the next KeyValue.
|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
LeaseException
Reports a problem with a lease
|
LeaseListener
LeaseListener is an interface meant to be implemented by users of the Leases class.
|
LeaseManager
Leases There are several server classes in HBase that need to track external clients that
occasionally send heartbeats.
|
LeaseManager.Lease
This class tracks a single Lease.
|
LeaseManager.LeaseStillHeldException
Thrown if we are asked to create a lease but lease on passed name already exists.
|
LogRoller
Runs periodically to determine if the WAL should be rolled.
|
MemStore
The MemStore holds in-memory modifications to the Store.
|
MemStoreCompactionStrategy
MemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for
choosing the next action to apply in an (in-memory) memstore compaction.
|
MemStoreCompactionStrategy.Action
Types of actions to be done on the pipeline upon MemStoreCompaction invocation.
|
MemStoreCompactor
The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the
compaction if requested.
|
MemStoreFlusher
Thread that flushes cache on request NOTE: This class extends Thread rather than Chore because
the sleep time can be interrupted when there is something to do, rather than the Chore sleep time
which is invariant.
|
MemStoreFlusher.FlushHandler |
MemStoreFlusher.FlushQueueEntry |
MemStoreFlusher.FlushRegionEntry
Datastructure used in the flush queue.
|
MemStoreLAB
A memstore-local allocation buffer.
|
MemStoreSegmentsIterator
The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments For
another iteration new instance of MemStoreSegmentsIterator needs to be created The iterator is
not thread-safe and must have only one instance per MemStore in each period of time
|
MemStoreSize
Data structure of three longs.
|
MemStoreSizing
Accounting of current heap and data sizes.
|
MemStoreSnapshot
MemStoreSnapshot is a Context Object to hold details of the snapshot taken on a MemStore. |
MetricsHeapMemoryManager
This class is for maintaining the various regionserver's heap memory manager statistics and
publishing them through the metrics interfaces.
|
MetricsHeapMemoryManagerSource
This interface will be implemented by a MetricsSource that will export metrics from
HeapMemoryManager in RegionServer into the hadoop metrics system.
|
MetricsHeapMemoryManagerSourceImpl
Hadoop2 implementation of MetricsHeapMemoryManagerSource.
|
MetricsRegion
This is the glue between the HRegion and whatever hadoop shim layer is loaded
(hbase-hadoop1-compat or hbase-hadoop2-compat).
|
MetricsRegionAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple
regions into the hadoop metrics system.
|
MetricsRegionAggregateSourceImpl |
MetricsRegionServer
Maintains regionserver statistics and publishes them through the metrics interfaces.
|
MetricsRegionServerQuotaSource
A collection of exposed metrics for space quotas from an HBase RegionServer.
|
MetricsRegionServerSource
Interface for classes that expose metrics about the regionserver.
|
MetricsRegionServerSourceFactory
Interface of a factory to create Metrics Sources used inside of regionservers.
|
MetricsRegionServerSourceFactoryImpl.FactoryStorage |
MetricsRegionServerWrapper
This is the interface that will expose RegionServer information to hadoop1/hadoop2
implementations of the MetricsRegionServerSource.
|
MetricsRegionServerWrapperImpl
Impl for exposing HRegionServer Information through Hadoop's metrics 2 system.
|
MetricsRegionSource
This interface will be implemented to allow single regions to push metrics into
MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
|
MetricsRegionWrapper
Interface of class that will wrap an HRegion and export numbers so they can be used in
MetricsRegionSource
|
MetricsRegionWrapperImpl |
MetricsTable |
MetricsTableAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple
regions of a table into the hadoop metrics system.
|
MetricsTableAggregateSourceImpl |
MetricsTableLatencies
Latency metrics for a specific table in a RegionServer.
|
MetricsTableLatenciesImpl.TableHistograms |
MetricsTableQueryMeter
Query Per Second for each table in a RegionServer.
|
MetricsTableQueryMeterImpl.TableMeters |
MetricsTableSource
This interface will be implemented to allow region server to push table metrics into
MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
|
MetricsTableWrapperAggregate
Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in
MetricsTableSource
|
MetricsTableWrapperAggregateImpl.MetricsTableValues |
MetricsUserAggregate |
MetricsUserAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple
users into the hadoop metrics system.
|
MetricsUserAggregateSourceImpl |
MetricsUserSource |
MetricsUserSource.ClientMetrics |
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
MultiVersionConcurrencyControl
Manages the read/write consistency.
|
MultiVersionConcurrencyControl.WriteEntry
Write number and whether write has completed given out at start of a write transaction.
|
MutableOnlineRegions
Interface to Map of online regions.
|
MutableSegment
A mutable segment in memstore, specifically the active segment.
|
NonLazyKeyValueScanner
A "non-lazy" scanner which always does a real seek operation.
|
NonReversedNonLazyKeyValueScanner
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does
a real seek operation.
|
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
OnlineRegions
Provides read-only access to the Regions presently online on the current RegionServer
|
OperationStatus
This class stores the Operation status code and the exception message that occurs in case of
failure of operations like put, delete, etc.
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
Region.Operation
Operation enum is used in
Region.startRegionOperation() and elsewhere to provide context
for various checks. |
Region.RowLock
Row lock held by a given thread.
|
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors loaded within a
Region . |
RegionCoprocessorHost.RegionEnvironment
Encapsulation of the environment of each coprocessor
|
RegionCoprocessorHost.TableCoprocessorAttribute |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
RegionScannerImpl
RegionScannerImpl is used to combine scanners from multiple Stores (aka column families).
|
RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about the Region Server.
|
RegionServerCoprocessorHost |
RegionServerCoprocessorHost.RegionServerEnvironment
Coprocessor environment extension providing access to region server related services.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
RegionServerServices.PostOpenDeployContext
Context for postOpenDeployTasks().
|
RegionServerServices.RegionStateTransitionContext |
RegionServerStoppedException
Thrown by the region server when it is in shutting down state.
|
RegionServerTableMetrics
Captures operation metrics by table.
|
RegionServicesForStores
Services a Store needs from a Region.
|
RegionSplitPolicy
A split policy determines when a Region should be split.
|
RegionSplitRestriction
A split restriction that restricts the pattern of the split point.
|
RemoteProcedureResultReporter
A thread which calls
reportProcedureDone to tell master the result of a remote procedure. |
ReplicationService
Gateway to Cluster Replication.
|
ReplicationSinkService
A sink for a replication stream has to expose this service.
|
ReplicationSourceService
A source for a replication stream has to expose this service.
|
ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
|
RowProcessor
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. For customization, use
Coprocessors instead.
|
RpcSchedulerFactory
A factory class that constructs an
RpcScheduler . |
RSRpcServices
Implements the regionserver RPC services.
|
RSRpcServices.RegionScannerHolder
Holder class which holds the RegionScanner, nextCallSeq and RpcCallbacks together.
|
RSRpcServices.RegionScannersCloseCallBack
An RpcCallBack that creates a list of scanners that needs to perform callBack operation on
completion of multiGets.
|
ScanInfo
Immutable information for scans over a store.
|
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) . |
ScannerContext.Builder |
ScannerContext.LimitFields
The different fields that can be used as limits in calls to
InternalScanner.next(java.util.List) and InternalScanner.next(java.util.List) |
ScannerContext.LimitScope
The various scopes where a limit can be enforced.
|
ScannerContext.NextState
The possible states a scanner may be in following a call to
InternalScanner.next(List) |
ScannerContext.ProgressFields |
ScannerIdGenerator
Generate a new style scanner id to prevent collision with previous started server or other RSs.
|
ScanOptions
This class gives you the ability to change the max versions and TTL options before opening a
scanner for a Store.
|
ScanType
Enum to distinguish general scan types.
|
SecureBulkLoadManager
Bulk loads in secure mode.
|
Segment
This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its
snapshot.
|
SegmentFactory
A singleton store segment factory.
|
ServerNonceManager
Implementation of nonce manager that stores nonces in a hash map and cleans them up after some
time; if nonce group/client ID is supplied, nonces are stored by client ID.
|
ServerNonceManager.OperationContext |
Shipper
This interface denotes a scanner as one which can ship cells.
|
ShipperListener
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped() is called |
SplitLogWorker
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 SplitWALRemoteProcedure
|
SplitLogWorker.TaskExecutor
Deprecated.
Objects implementing this interface actually do the task that has been acquired by a
SplitLogWorker . |
SplitLogWorker.TaskExecutor.Status |
Store
Interface for objects that hold a column family in a Region.
|
StoreConfigInformation
A more restricted interface for HStore.
|
StoreContext
This carries the immutable information and references on some of the meta data about the HStore.
|
StoreContext.Builder |
StoreEngine
StoreEngine is a factory that can create the objects necessary for HStore to operate.
|
StoreEngine.IOExceptionRunnable |
StoreFile
An interface to describe a store data file.
|
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
StoreFileManager
Manages the store files and basic metadata about that that determines the logical structure (e.g.
|
StoreFileReader
Reader for a StoreFile.
|
StorefileRefresherChore
A chore for refreshing the store files for secondary regions hosted in the region server.
|
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
StoreFileWriter
A StoreFile writer.
|
StoreFileWriter.Builder |
StoreFlushContext
A package protected interface for a store flushing.
|
StoreFlusher
Store flusher interface.
|
StoreScanner
Scanner scans both the memstore and the Store.
|
StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files for stripe
compaction.
|
StripeStoreConfig
Configuration class for stripe store and compactions.
|
StripeStoreFileManager
Stripe implementation of StoreFileManager.
|
StripeStoreFileManager.State
The state class.
|
StripeStoreFlusher.StripeFlushRequest
Stripe flush request wrapper that writes a non-striped file.
|
TimeRangeTracker
Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in
interval notation.
|
TimeRangeTracker.Type |
VersionedSegmentsList
A list of segment managers coupled with the version of the memstore (version at the time it was
created).
|
WrongRegionException
Thrown when a request contains a key which is not part of this region
|
Class and Description |
---|
AbstractMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files.
|
CellSink
A sink of cells that allows appending cells to the Writers that implement it.
|
CreateStoreFileWriterParams |
DateTieredMultiFileWriter
class for cell sink that separates the provided cells into multiple files for date tiered
compaction.
|
HRegion
Regions store data for a certain region of a table.
|
HStore
A Store holds a column family in a Region.
|
HStoreFile
A Store data file.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
ScanInfo
Immutable information for scans over a store.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
StoreConfigInformation
A more restricted interface for HStore.
|
StoreFile
An interface to describe a store data file.
|
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
StoreFileWriter
A StoreFile writer.
|
StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files for stripe
compaction.
|
StripeStoreConfig
Configuration class for stripe store and compactions.
|
StripeStoreFlusher.StripeFlushRequest
Stripe flush request wrapper that writes a non-striped file.
|
Class and Description |
---|
HRegion
Regions store data for a certain region of a table.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
KeyValueScanner
Scanner that returns the next KeyValue.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
SplitLogWorker.TaskExecutor
Deprecated.
Objects implementing this interface actually do the task that has been acquired by a
SplitLogWorker . |
Class and Description |
---|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
Class and Description |
---|
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors loaded within a
Region . |
ScanInfo
Immutable information for scans over a store.
|
ScanType
Enum to distinguish general scan types.
|
ShipperListener
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped() is called |
Class and Description |
---|
HRegion
Regions store data for a certain region of a table.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
CreateStoreFileWriterParams |
HRegionFileSystem
View to an on-disk Region.
|
StoreContext
This carries the immutable information and references on some of the meta data about the HStore.
|
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
StoreFileWriter
A StoreFile writer.
|
Class and Description |
---|
HStore
A Store holds a column family in a Region.
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Class and Description |
---|
MultiVersionConcurrencyControl
Manages the read/write consistency.
|
MultiVersionConcurrencyControl.WriteEntry
Write number and whether write has completed given out at start of a write transaction.
|
Class and Description |
---|
ReplicationService
Gateway to Cluster Replication.
|
ReplicationSinkService
A sink for a replication stream has to expose this service.
|
Class and Description |
---|
ReplicationService
Gateway to Cluster Replication.
|
ReplicationSinkService
A sink for a replication stream has to expose this service.
|
ReplicationSourceService
A source for a replication stream has to expose this service.
|
Class and Description |
---|
FlushLifeCycleTracker
Used to track flush execution.
|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
ScanType
Enum to distinguish general scan types.
|
Store
Interface for objects that hold a column family in a Region.
|
Class and Description |
---|
InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
OperationStatus
This class stores the Operation status code and the exception message that occurs in case of
failure of operations like put, delete, etc.
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
ShipperListener
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped() is called |
Class and Description |
---|
HRegion
Regions store data for a certain region of a table.
|
HRegionFileSystem
View to an on-disk Region.
|
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
Class and Description |
---|
OnlineRegions
Provides read-only access to the Regions presently online on the current RegionServer
|
Region
Region is a subset of HRegion with operations required for the
Coprocessors . |
Class and Description |
---|
BloomType |
Class and Description |
---|
MiniBatchOperationInProgress
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
Class and Description |
---|
BloomType |
CellSink
A sink of cells that allows appending cells to the Writers that implement it.
|
HRegion
Regions store data for a certain region of a table.
|
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
KeyValueScanner
Scanner that returns the next KeyValue.
|
NonLazyKeyValueScanner
A "non-lazy" scanner which always does a real seek operation.
|
NonReversedNonLazyKeyValueScanner
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does
a real seek operation.
|
Shipper
This interface denotes a scanner as one which can ship cells.
|
ShipperListener
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped() is called |
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
Class and Description |
---|
HRegionFileSystem
View to an on-disk Region.
|
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
Class and Description |
---|
LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
|
MultiVersionConcurrencyControl
Manages the read/write consistency.
|
MultiVersionConcurrencyControl.WriteEntry
Write number and whether write has completed given out at start of a write transaction.
|
RegionServerServices
A curated subset of services provided by
HRegionServer . |
SequenceId
Interface which abstracts implementations on log sequenceId assignment
|
StoreFileWriter
A StoreFile writer.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.