Package org.apache.hadoop.hbase.regionserver
package org.apache.hadoop.hbase.regionserver
-
ClassDescriptionorg.apache.hadoop.hbase.regionserver.AbstractMemStoreAn abstract class, which implements the behaviour shared by all concrete memstore instances.org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriterBase class for cell sink that separates the provided cells into multiple files.org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactoryorg.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategyAdaptive is a heuristic that chooses whether to apply data compaction or not based on the level of redundancy in the data.org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategyBasic strategy chooses between two actions: flattening a segment or merging indices of all segments in the pipeline.org.apache.hadoop.hbase.regionserver.BloomTypeorg.apache.hadoop.hbase.regionserver.BootstrapNodeManagerManage the bootstrap node list at region server side.org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleanerThis Chore, every time it runs, will clear the unsused HFiles in the data folder.org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicyThis class represents a split policy which makes the split decision based on how busy a region is.org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offsetorg.apache.hadoop.hbase.regionserver.CellArrayImmutableSegmentCellArrayImmutableSegment extends the API supported by a
Segment
, andImmutableSegment
.org.apache.hadoop.hbase.regionserver.CellArrayMap<T extends org.apache.hadoop.hbase.Cell>CellArrayMap is a simple array of Cells and cannot be allocated off-heap.org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegmentCellChunkImmutableSegment extends the API supported by aSegment
, andImmutableSegment
.org.apache.hadoop.hbase.regionserver.CellChunkMap<T extends org.apache.hadoop.hbase.Cell>CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.org.apache.hadoop.hbase.regionserver.CellFlatMap<T extends org.apache.hadoop.hbase.Cell>CellFlatMap stores a constant number of elements and is immutable after creation stage.org.apache.hadoop.hbase.regionserver.CellSet<T extends org.apache.hadoop.hbase.Cell>ASet
ofCell
s, where an add will overwrite the entry if already exists in the set.org.apache.hadoop.hbase.regionserver.CellSinkA sink of cells that allows appending cells to the Writers that implement it.org.apache.hadoop.hbase.regionserver.ChangedReadersObserverIf set of MapFile.Readers in Store change, implementors are notified.org.apache.hadoop.hbase.regionserver.ChunkA chunk of memory out of which allocations are sliced.org.apache.hadoop.hbase.regionserver.ChunkCreatorDoes the management of memstoreLAB chunk creations.org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkTypeTypes of chunks, based on their sizesorg.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandlerEvent handler that handles the removal and archival of the compacted hfilesorg.apache.hadoop.hbase.regionserver.CompactedHFilesDischargerA 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.org.apache.hadoop.hbase.regionserver.CompactingMemStoreA memstore implementation which supports in-memory compaction.org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexTypeTypes of indexes (part of immutable segments) to be used after flattening, compaction, or merge are applied.org.apache.hadoop.hbase.regionserver.CompactionPipelineThe compaction pipeline of aCompactingMemStore
, is a FIFO queue of segments.org.apache.hadoop.hbase.regionserver.CompactionToolorg.apache.hadoop.hbase.regionserver.CompactSplitCompact region on request and then run split if appropriateorg.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTrackerorg.apache.hadoop.hbase.regionserver.CompositeImmutableSegmentThe CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicyARegionSplitPolicy
implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParamsorg.apache.hadoop.hbase.regionserver.CSLMImmutableSegmentCSLMImmutableSegment is an abstract class that extends the API supported by aSegment
, andImmutableSegment
.org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilderHelper class for CP hooks to change max versions and TTL.org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriterclass for cell sink that separates the provided cells into multiple files for date tiered compaction.org.apache.hadoop.hbase.regionserver.DateTieredStoreEngineHBASE-15400 This store engine allows us to store data in date tiered layout with exponential sizing so that the more recent data has more granularity.org.apache.hadoop.hbase.regionserver.DefaultMemStoreThe MemStore holds in-memory modifications to the Store.org.apache.hadoop.hbase.regionserver.DefaultStoreEngineDefault StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.org.apache.hadoop.hbase.regionserver.DefaultStoreFlusherDefault implementation of StoreFlusher.org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicyDeprecated.since 3.0.0 and will be removed in 4.0.0.org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestrictionARegionSplitRestriction
implementation that groups rows by a prefix of the row-key with a delimiter.org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicyARegionSplitPolicy
that disables region splits.org.apache.hadoop.hbase.regionserver.DumpRegionServerMetricsUtility for doing JSON and MBeans.org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategyorg.apache.hadoop.hbase.regionserver.FavoredNodesForRegionAbstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactoryFactory to use when you want to use theFifoRpcScheduler
org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicyAFlushPolicy
that only flushes store larger a given threshold.org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicyAFlushPolicy
that always flushes all stores for a given region.org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicyAFlushPolicy
that only flushes store larger a given threshold.org.apache.hadoop.hbase.regionserver.FlushLifeCycleTrackerUsed to track flush execution.org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicyAFlushPolicy
that only flushes store larger than a given threshold.org.apache.hadoop.hbase.regionserver.FlushPolicyA flush policy determines the stores that need to be flushed when flushing a region.org.apache.hadoop.hbase.regionserver.FlushPolicyFactoryThe class that creates a flush policy from a conf and HTableDescriptor.org.apache.hadoop.hbase.regionserver.FlushRegionCallableorg.apache.hadoop.hbase.regionserver.FlushRequesterRequest a flush.org.apache.hadoop.hbase.regionserver.FlushRequestListenerListener which will get notified regarding flush requests of regions.org.apache.hadoop.hbase.regionserver.HeapMemoryManagerManages tuning of Heap memory usingHeapMemoryTuner
.org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTuneObserverEvery class that wants to observe heap memory tune actions must implement this interface.org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContextPOJO to pass all the relevant information required to do the heap memory tuning.org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResultPOJO which holds the result of memory tuning done by HeapMemoryTuner implementation.org.apache.hadoop.hbase.regionserver.HeapMemoryTunerMakes the decision regarding proper sizing of the heap memory.org.apache.hadoop.hbase.regionserver.HMobStoreThe store implementation to save MOBs (medium objects), it extends the HStore.org.apache.hadoop.hbase.regionserver.HRegionRegions store data for a certain region of a table.org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListenerListener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload callorg.apache.hadoop.hbase.regionserver.HRegion.FlushResultorg.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Resultorg.apache.hadoop.hbase.regionserver.HRegion.FlushResultImplObjects from this class are created when flushing to describe all the different states that that method ends up in.org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResultA result object from prepare flush cache stageorg.apache.hadoop.hbase.regionserver.HRegion.RowLockImplClass used to represent a lock on a row.org.apache.hadoop.hbase.regionserver.HRegionFileSystemView to an on-disk Region.org.apache.hadoop.hbase.regionserver.HRegionServerHRegionServer makes a set of HRegions available to clients.org.apache.hadoop.hbase.regionserver.HRegionServerCommandLineClass responsible for parsing the command line and starting the RegionServer.org.apache.hadoop.hbase.regionserver.HRegionWALFileSystemA Wrapper for the region FileSystem operations adding WAL specific operationsorg.apache.hadoop.hbase.regionserver.HStoreA Store holds a column family in a Region.org.apache.hadoop.hbase.regionserver.HStoreFileA Store data file.org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLABA MemStoreLAB implementation which wraps N MemStoreLABs.org.apache.hadoop.hbase.regionserver.ImmutableSegmentImmutableSegment is an abstract class that extends the API supported by aSegment
, and is not needed for aMutableSegment
.org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicySplit 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.org.apache.hadoop.hbase.regionserver.InputStreamBlockDistributionComputes the HDFSBlockDistribution for a file based on the underlying located blocks for an HdfsDataInputStream reading that file.org.apache.hadoop.hbase.regionserver.InternalScanSpecial scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.org.apache.hadoop.hbase.regionserver.InternalScannerInternal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityExceptionThrown if Mutation'sDurability
is skip wal but table need replication.org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicyDeprecated.since 3.0.0 and will be removed in 4.0.0.org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestrictionARegionSplitRestriction
implementation that groups rows by a prefix of the row-key.org.apache.hadoop.hbase.regionserver.KeyValueHeapImplements a heap merge across any number of KeyValueScanners.org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparatororg.apache.hadoop.hbase.regionserver.KeyValueScannerScanner that returns the next KeyValue.org.apache.hadoop.hbase.regionserver.LastSequenceIdLast flushed sequence Ids for the regions and their stores on region serverorg.apache.hadoop.hbase.regionserver.LeaseExceptionReports a problem with a leaseorg.apache.hadoop.hbase.regionserver.LeaseListenerLeaseListener is an interface meant to be implemented by users of the Leases class.org.apache.hadoop.hbase.regionserver.LeaseManagerLeases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldExceptionThrown if we are asked to create a lease but lease on passed name already exists.org.apache.hadoop.hbase.regionserver.LogRollerRuns periodically to determine if the WAL should be rolled.org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactoryFactory to use when you want to use theMasterFifoRpcScheduler
org.apache.hadoop.hbase.regionserver.MemStoreThe MemStore holds in-memory modifications to the Store.org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategyMemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for choosing the next action to apply in an (in-memory) memstore compaction.org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.ActionTypes of actions to be done on the pipeline upon MemStoreCompaction invocation.org.apache.hadoop.hbase.regionserver.MemStoreCompactorThe ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIteratorThe MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQMorg.apache.hadoop.hbase.regionserver.MemStoreFlusherThread 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.org.apache.hadoop.hbase.regionserver.MemStoreLABA memstore-local allocation buffer.org.apache.hadoop.hbase.regionserver.MemStoreLABImplA memstore-local allocation buffer.org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIteratorThe MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for simple merge operation meaning it is NOT based on SQMorg.apache.hadoop.hbase.regionserver.MemStoreSegmentsIteratorThe 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 timeorg.apache.hadoop.hbase.regionserver.MemStoreSizeData structure of three longs.org.apache.hadoop.hbase.regionserver.MemStoreSizingAccounting of current heap and data sizes.org.apache.hadoop.hbase.regionserver.MemStoreSnapshotMemStoreSnapshot
is a Context Object to hold details of the snapshot taken on a MemStore.org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerThis class is for maintaining the various regionserver's heap memory manager statistics and publishing them through the metrics interfaces.org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceThis interface will be implemented by a MetricsSource that will export metrics from HeapMemoryManager in RegionServer into the hadoop metrics system.org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImplHadoop2 implementation of MetricsHeapMemoryManagerSource.org.apache.hadoop.hbase.regionserver.MetricsRegionThis is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceThis interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImplorg.apache.hadoop.hbase.regionserver.MetricsRegionServerMaintains regionserver statistics and publishes them through the metrics interfaces.org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceA collection of exposed metrics for space quotas from an HBase RegionServer.org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImplImplementation ofMetricsRegionServerQuotaSource
.org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceInterface for classes that expose metrics about the regionserver.org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryInterface of a factory to create Metrics Sources used inside of regionservers.org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImplFactory to create MetricsRegionServerSource when given a MetricsRegionServerWrapperorg.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorageorg.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImplHadoop2 implementation of MetricsRegionServerSource.org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperThis is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.org.apache.hadoop.hbase.regionserver.MetricsRegionSourceThis interface will be implemented to allow single regions to push metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImplorg.apache.hadoop.hbase.regionserver.MetricsRegionWrapperInterface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSourceorg.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImplorg.apache.hadoop.hbase.regionserver.MetricsTableorg.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceThis interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImplorg.apache.hadoop.hbase.regionserver.MetricsTableSourceThis 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.org.apache.hadoop.hbase.regionserver.MetricsTableSourceImplorg.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateInterface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSourceorg.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImplorg.apache.hadoop.hbase.regionserver.MetricsUserAggregateorg.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactoryorg.apache.hadoop.hbase.regionserver.MetricsUserAggregateImplorg.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceThis interface will be implemented by a MetricsSource that will export metrics from multiple users into the hadoop metrics system.org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImplorg.apache.hadoop.hbase.regionserver.MetricsUserSourceorg.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetricsorg.apache.hadoop.hbase.regionserver.MetricsUserSourceImplorg.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<T>Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.org.apache.hadoop.hbase.regionserver.MobStoreScannerScanner scans both the memstore and the MOB Store.org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControlManages the read/write consistency.org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntryWrite number and whether write has completed given out at start of a write transaction.org.apache.hadoop.hbase.regionserver.MutableOnlineRegionsInterface to Map of online regions.org.apache.hadoop.hbase.regionserver.MutableSegmentA mutable segment in memstore, specifically the active segment.org.apache.hadoop.hbase.regionserver.NoLimitScannerContextThis is a specialScannerContext
subclass that is designed to be used globally when limits should not be enforced during invocations ofInternalScanner.next(java.util.List)
orInternalScanner.next(java.util.List)
.org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScannerA "non-lazy" scanner which always does a real seek operation.org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScannerA "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.org.apache.hadoop.hbase.regionserver.NoRegionSplitRestrictionARegionSplitRestriction
implementation that does nothing.org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyExceptionThrown if request for nonexistent column family.org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tagsorg.apache.hadoop.hbase.regionserver.OffheapChunkAn off heap chunk implementation.org.apache.hadoop.hbase.regionserver.OnheapChunkAn on heap chunk implementation.org.apache.hadoop.hbase.regionserver.OnlineRegionsProvides read-only access to the Regions presently online on the current RegionServerorg.apache.hadoop.hbase.regionserver.OperationStatusThis class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifierClass to submit requests for PrefetchExecutor depending on configuration changeorg.apache.hadoop.hbase.regionserver.ReadPointCalculationLockLock to manage concurrency betweenRegionScanner
andHRegion.getSmallestReadPoint()
.org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockTypeorg.apache.hadoop.hbase.regionserver.RegionRegion is a subset of HRegion with operations required for theCoprocessors
.org.apache.hadoop.hbase.regionserver.Region.OperationOperation enum is used inRegion.startRegionOperation()
and elsewhere to provide context for various checks.org.apache.hadoop.hbase.regionserver.Region.RowLockRow lock held by a given thread.org.apache.hadoop.hbase.regionserver.RegionCoprocessorHostImplements the coprocessor environment and runtime support for coprocessors loaded within aRegion
.org.apache.hadoop.hbase.regionserver.RegionScannerRegionScanner describes iterators over rows in an HRegion.org.apache.hadoop.hbase.regionserver.RegionServerAbortedExceptionThrown by the region server when it is aborting.org.apache.hadoop.hbase.regionserver.RegionServerAccountingRegionServerAccounting keeps record of some basic real time information about the Region Server.org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHostorg.apache.hadoop.hbase.regionserver.RegionServerRunningExceptionThrown if the region server log directory exists (which indicates another region server is running at the same address)org.apache.hadoop.hbase.regionserver.RegionServerServicesA curated subset of services provided byHRegionServer
.org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContextContext for postOpenDeployTasks().org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContextorg.apache.hadoop.hbase.regionserver.RegionServerStoppedExceptionThrown by the region server when it is in shutting down state.org.apache.hadoop.hbase.regionserver.RegionServicesForStoresServices a Store needs from a Region.org.apache.hadoop.hbase.regionserver.RegionSplitPolicyA split policy determines when a Region should be split.org.apache.hadoop.hbase.regionserver.RegionSplitRestrictionA split restriction that restricts the pattern of the split point.org.apache.hadoop.hbase.regionserver.ReplicationServiceGateway to Cluster Replication.org.apache.hadoop.hbase.regionserver.ReplicationSinkServiceA sink for a replication stream has to expose this service.org.apache.hadoop.hbase.regionserver.ReplicationSourceServiceA source for a replication stream has to expose this service.org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeapReversedKeyValueHeap is used for supporting reversed scanning.org.apache.hadoop.hbase.regionserver.ReversedMobStoreScannerReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.org.apache.hadoop.hbase.regionserver.ReversedStoreScannerReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.org.apache.hadoop.hbase.regionserver.RowTooBigExceptionDeprecated.since 0.99.0.org.apache.hadoop.hbase.regionserver.RpcSchedulerFactoryA factory class that constructs anRpcScheduler
.org.apache.hadoop.hbase.regionserver.RSRpcServicesImplements the regionserver RPC services.org.apache.hadoop.hbase.regionserver.RSSnapshotVerifierUsed bySnapshotVerifyProcedure
to verify if the region info and store file info in RegionManifest are intact.org.apache.hadoop.hbase.regionserver.ScanInfoImmutable information for scans over a store.org.apache.hadoop.hbase.regionserver.ScannerContextScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations ofInternalScanner.next(java.util.List)
andInternalScanner.next(java.util.List)
.org.apache.hadoop.hbase.regionserver.ScannerContext.Builderorg.apache.hadoop.hbase.regionserver.ScannerContext.LimitScopeThe various scopes where a limit can be enforced.org.apache.hadoop.hbase.regionserver.ScannerContext.NextStateThe possible states a scanner may be in following a call toInternalScanner.next(List)
org.apache.hadoop.hbase.regionserver.ScannerIdGeneratorGenerate a new style scanner id to prevent collision with previous started server or other RSs.org.apache.hadoop.hbase.regionserver.ScanOptionsThis class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.org.apache.hadoop.hbase.regionserver.ScanTypeEnum to distinguish general scan types.org.apache.hadoop.hbase.regionserver.SecureBulkLoadManagerBulk loads in secure mode.org.apache.hadoop.hbase.regionserver.SegmentThis is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.org.apache.hadoop.hbase.regionserver.SegmentFactoryA singleton store segment factory.org.apache.hadoop.hbase.regionserver.SegmentScannerA scanner of a single memstore segment.org.apache.hadoop.hbase.regionserver.SequenceIdInterface which abstracts implementations on log sequenceId assignmentorg.apache.hadoop.hbase.regionserver.ServerNonceManagerImplementation 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.org.apache.hadoop.hbase.regionserver.ShipperThis interface denotes a scanner as one which can ship cells.org.apache.hadoop.hbase.regionserver.ShipperListenerImplementors of this interface are the ones who needs to do some action when theShipper.shipped()
is calledorg.apache.hadoop.hbase.regionserver.ShutdownHookManage regionserver shutdown hooks.org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactoryConstructs aSimpleRpcScheduler
.org.apache.hadoop.hbase.regionserver.SnapshotRegionCallableorg.apache.hadoop.hbase.regionserver.SnapshotSegmentScannerA basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a single pass, no reverse scanning or inserts happening.org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallableorg.apache.hadoop.hbase.regionserver.SplitLogWorkerDeprecated.since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALRemoteProcedureorg.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutorObjects implementing this interface actually do the task that has been acquired by aSplitLogWorker
.org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Statusorg.apache.hadoop.hbase.regionserver.SplitWALCallableThis callable is used to do the real split WAL task.org.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitExceptionorg.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitExceptionorg.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitExceptionorg.apache.hadoop.hbase.regionserver.SteppingSplitPolicyorg.apache.hadoop.hbase.regionserver.StoreInterface for objects that hold a column family in a Region.org.apache.hadoop.hbase.regionserver.StoreConfigInformationA more restricted interface for HStore.org.apache.hadoop.hbase.regionserver.StoreContextThis carries the immutable information and references on some of the meta data about the HStore.org.apache.hadoop.hbase.regionserver.StoreContext.Builderorg.apache.hadoop.hbase.regionserver.StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy, C extends org.apache.hadoop.hbase.regionserver.compactions.Compactor<?>, SFM extends org.apache.hadoop.hbase.regionserver.StoreFileManager> StoreEngine is a factory that can create the objects necessary for HStore to operate.org.apache.hadoop.hbase.regionserver.StoreFileAn interface to describe a store data file.org.apache.hadoop.hbase.regionserver.StoreFileInfoDescribe a StoreFile (hfile, reference, link)org.apache.hadoop.hbase.regionserver.StoreFileManagerManages the store files and basic metadata about that that determines the logical structure (e.g.org.apache.hadoop.hbase.regionserver.StoreFileReaderReader for a StoreFile.org.apache.hadoop.hbase.regionserver.StorefileRefresherChoreA chore for refreshing the store files for secondary regions hosted in the region server.org.apache.hadoop.hbase.regionserver.StoreFileScannerKeyValueScanner adaptor over the Reader.org.apache.hadoop.hbase.regionserver.StoreFileWriterA StoreFile writer.org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builderorg.apache.hadoop.hbase.regionserver.StoreScannerScanner scans both the memstore and the Store.org.apache.hadoop.hbase.regionserver.StoreUtilsUtility functions for region server storage layer.org.apache.hadoop.hbase.regionserver.StripeMultiFileWriterBase class for cell sink that separates the provided cells into multiple files for stripe compaction.org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriterMultiWriter that separates the cells based on fixed row-key boundaries.org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriterMultiWriter that separates the cells based on target cell number per file and file count.org.apache.hadoop.hbase.regionserver.StripeStoreConfigConfiguration class for stripe store and compactions.org.apache.hadoop.hbase.regionserver.StripeStoreEngineThe storage engine that implements the stripe-based store/compaction scheme.org.apache.hadoop.hbase.regionserver.StripeStoreFileManagerStripe implementation ofStoreFileManager
.org.apache.hadoop.hbase.regionserver.StripeStoreFlusherStripe implementation of StoreFlusher.org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequestStripe flush request wrapper based on boundaries.org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequestStripe flush request wrapper based on size.org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequestStripe flush request wrapper that writes a non-striped file.org.apache.hadoop.hbase.regionserver.TimeRangeTrackerStores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTrackerorg.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTrackerorg.apache.hadoop.hbase.regionserver.TimeRangeTracker.Typeorg.apache.hadoop.hbase.regionserver.VersionedSegmentsListA list of segment managers coupled with the version of the memstore (version at the time it was created).org.apache.hadoop.hbase.regionserver.WrongRegionExceptionThrown when a request contains a key which is not part of this region