Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id AA0A9200C84 for ; Sun, 14 May 2017 16:58:48 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id A8C63160BA6; Sun, 14 May 2017 14:58:48 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 6DE26160BD2 for ; Sun, 14 May 2017 16:58:46 +0200 (CEST) Received: (qmail 51167 invoked by uid 500); 14 May 2017 14:58:44 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 50623 invoked by uid 99); 14 May 2017 14:58:44 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Sun, 14 May 2017 14:58:44 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 4AE38E9687; Sun, 14 May 2017 14:58:44 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Sun, 14 May 2017 14:58:51 -0000 Message-Id: <7ce0870d60254333bd18077cdb799991@git.apache.org> In-Reply-To: <2602ba6e024c411c8745bd30fc02383b@git.apache.org> References: <2602ba6e024c411c8745bd30fc02383b@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [08/13] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Sun, 14 May 2017 14:58:48 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/regionserver/package-summary.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/package-summary.html b/devapidocs/org/apache/hadoop/hbase/regionserver/package-summary.html index 61f3785..e764eb2 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/package-summary.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/package-summary.html @@ -423,37 +423,44 @@ +CellChunkMap + +
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.
+ + + CellFlatMap
CellFlatMap stores a constant number of elements and is immutable after creation stage.
- + CellSet
A Set of Cells, where an add will overwrite the entry if already exists in the set.
- + Chunk
A chunk of memory out of which allocations are sliced.
- + ChunkCreator
Does the management of memstoreLAB chunk creations.
- + CompactedHFilesDischargeHandler
Event handler that handles the removal and archival of the compacted hfiles
- + CompactedHFilesDischarger
A chore service that periodically cleans up the compacted files when there are no active readers @@ -461,58 +468,58 @@ file entries
- + CompactingMemStore
A memstore implementation which supports in-memory compaction.
- + CompactionPipeline
The compaction pipeline of a CompactingMemStore, is a FIFO queue of segments.
- + CompactionTool   - + CompactionTool.CompactionInputFormat
Input format that uses store files block location as input split locality.
- + CompactionTool.CompactionMapper   - + CompactionTool.CompactionWorker
Class responsible to execute the Compaction on the specified path.
- + CompactSplitThread
Compact region on request and then run split if appropriate
- + CompactSplitThread.Rejection
Cleanup class to use when rejecting a compaction request from the queue.
- + 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 @@ -520,135 +527,135 @@ size.
- + DateTieredMultiFileWriter
class for cell sink that separates the provided cells into multiple files for date tiered compaction.
- + DateTieredStoreEngine
HBASE-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.
- + DefaultHeapMemoryTuner
The default implementation for the HeapMemoryTuner.
- + DefaultMemStore
The MemStore holds in-memory modifications to the Store.
- + DefaultStoreEngine
Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
- + DefaultStoreFileManager
Default implementation of StoreFileManager.
- + DefaultStoreFlusher
Default implementation of StoreFlusher.
- + DelimitedKeyPrefixRegionSplitPolicy
A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key with a delimiter.
- + DisabledRegionSplitPolicy
A RegionSplitPolicy that disables region splits.
- + FifoRpcSchedulerFactory
Factory to use when you want to use the FifoRpcScheduler
- + FlushAllLargeStoresPolicy
A FlushPolicy that only flushes store larger a given threshold.
- + FlushAllStoresPolicy
A FlushPolicy that always flushes all stores for a given region.
- + FlushLargeStoresPolicy
A FlushPolicy that only flushes store larger a given threshold.
- + FlushNonSloppyStoresFirstPolicy
A FlushPolicy that only flushes store larger than a given threshold.
- + FlushPolicy
A flush policy determines the stores that need to be flushed when flushing a region.
- + FlushPolicyFactory
The class that creates a flush policy from a conf and HTableDescriptor.
- + HeapMemoryManager
Manages tuning of Heap memory using HeapMemoryTuner.
- + 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.
- + HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
- + HRegion   - + HRegion.BatchOperation<T>
Struct-like class that tracks the progress of a batch operation, @@ -656,100 +663,100 @@ is proceeding.
- + HRegion.FlushResultImpl
Objects from this class are created when flushing to describe all the different states that that method ends up in.
- + HRegion.MutationBatch   - + 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.ReplayBatch   - + 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.CompactionChecker   - + HRegionServer.MovedRegionInfo   - + HRegionServer.MovedRegionsCleaner
Creates a Chore thread to clean the moved region cache.
- + HRegionServer.PeriodicMemstoreFlusher   - + HRegionServerCommandLine
Class responsible for parsing the command line and starting the RegionServer.
- + HStore
A Store holds a column family in a Region.
- + ImmutableMemStoreLAB
A MemStoreLAB implementation which wraps N MemStoreLABs.
- + 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 @@ -757,14 +764,14 @@ region split size, whichever is smaller.
- + InternalScan
Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
- + KeyPrefixRegionSplitPolicy
A custom RegionSplitPolicy implementing a SplitPolicy that groups @@ -773,17 +780,17 @@ This ensures that a region is not split "inside" a prefix of a row key.
- + KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
- + KeyValueHeap.KVScannerComparator   - + Leases
Leases @@ -792,33 +799,33 @@ clients that occasionally send heartbeats.
- + Leases.Lease
This class tracks a single Lease.
- + LogRoller
Runs periodically to determine if the WAL should be rolled.
- + MemStoreCompactor
The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.
- + MemStoreCompactorSegmentsIterator
The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQM
- + MemStoreFlusher
Thread that flushes cache on request @@ -828,32 +835,32 @@ sleep time which is invariant.
- + MemStoreFlusher.FlushRegionEntry
Datastructure used in the flush queue.
- + MemStoreFlusher.WakeupFlushThread
Token to insert into the flush queue that ensures that the flusher does not sleep
- + MemStoreLABImpl
A memstore-local allocation buffer.
- + MemStoreMergerSegmentsIterator
The MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for simple merge operation meaning it is NOT based on SQM
- + MemStoreSegmentsIterator
The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments @@ -862,43 +869,43 @@ in each period of time
- + MemstoreSize
Wraps the data size part and total heap space occupied by the memstore.
- + MemStoreSnapshot
Holds 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.
- + 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).
- + MetricsRegionAggregateSourceImpl   - + MetricsRegionServer
@@ -906,96 +913,96 @@ and publishing them through the metrics interfaces.
- + MetricsRegionServerSourceFactoryImpl
Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
- + MetricsRegionServerSourceImpl
Hadoop2 implementation of MetricsRegionServerSource.
- + MetricsRegionServerWrapperImpl
Impl for exposing HRegionServer Information through Hadoop's metrics 2 system.
- + MetricsRegionSourceImpl   - + MetricsRegionWrapperImpl   - + MetricsTable   - + MetricsTableAggregateSourceImpl   - + MetricsTableSourceImpl   - + MetricsTableWrapperAggregateImpl   - + MetricsTableWrapperAggregateImpl.MetricsTableValues   - + MiniBatchOperationInProgress<T>
Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
- + MobReferenceOnlyFilter
A filter that returns the cells which have mob reference tags.
- + MobStoreScanner
Scanner scans both the memstore and the MOB Store.
- + MultiRowMutationProcessor
A MultiRowProcessor that performs multiple puts and deletes.
- + MultiVersionConcurrencyControl
Manages the read/write consistency.
- + MultiVersionConcurrencyControl.WriteEntry
Write number and whether write has completed given out at start of a write transaction.
- + MutableSegment
A mutable segment in memstore, specifically the active segment.
- + NoLimitScannerContext
This is a special ScannerContext subclass that is designed to be used globally when @@ -1003,222 +1010,222 @@ or InternalScanner.next(java.util.List).
- + 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.
- + NoOpHeapMemoryTuner
An implementation of HeapMemoryTuner which is not doing any tuning activity but just allows to continue with old style fixed proportions.
- + NoTagByteBufferChunkCell
ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
- + OffheapChunk
An off heap chunk implementation.
- + OnheapChunk
An on heap chunk implementation.
- + OperationStatus
This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
- + RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors loaded within a Region.
- + RegionCoprocessorHost.CoprocessorOperation   - + RegionCoprocessorHost.EndpointOperation   - + RegionCoprocessorHost.EndpointOperationWithResult<T>   - + RegionCoprocessorHost.RegionEnvironment
Encapsulation of the environment of each coprocessor
- + RegionCoprocessorHost.RegionOperation   - + RegionCoprocessorHost.RegionOperationWithResult<T>   - + RegionCoprocessorHost.TableCoprocessorAttribute   - + RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about the Region Server.
- + RegionServerCoprocessorHost   - + RegionServerCoprocessorHost.CoprocessOperationWithResult<T>   - + RegionServerCoprocessorHost.CoprocessorOperation   - + RegionServerCoprocessorHost.EnvironmentPriorityComparator
Environment priority comparator.
- + RegionServerCoprocessorHost.RegionServerEnvironment
Coprocessor environment extension providing access to region server related services.
- + RegionServerServices.PostOpenDeployContext
Context for postOpenDeployTasks().
- + RegionServerServices.RegionStateTransitionContext   - + RegionServicesForStores
Services a Store needs from a Region.
- + RegionSplitPolicy
A split policy determines when a region should be split.
- + RegionUnassigner
Used to unssign a region when we hit FNFE.
- + ReversedKeyValueHeap
ReversedKeyValueHeap is used for supporting reversed scanning.
- + ReversedKeyValueHeap.ReversedKVScannerComparator
In ReversedKVScannerComparator, we compare the row of scanners' peek values first, sort bigger one before the smaller one.
- + ReversedMobStoreScanner
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.
- + ReversedRegionScannerImpl
ReversibleRegionScannerImpl extends from RegionScannerImpl, and is used to support reversed scanning.
- + ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
- + RSDumpServlet   - + RSRpcServices
Implements the regionserver RPC services.
- + RSRpcServices.RegionScannerCloseCallBack
An Rpc callback for closing a RegionScanner.
- + 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.
- + RSStatusServlet   - + ScanInfo
Immutable information for scans over a store.
- + ScannerContext
ScannerContext instances encapsulate limit tracking AND progress towards those limits during @@ -1226,268 +1233,268 @@ 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)
- + SecureBulkLoadManager
Bulk loads in secure mode.
- + SecureBulkLoadManager.SecureBulkLoadListener   - + 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.
- + SegmentScanner
A scanner of a single memstore segment.
- + 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   - + ShutdownHook
Manage regionserver shutdown hooks.
- + ShutdownHook.DoNothingStoppable   - + ShutdownHook.DoNothingThread   - + ShutdownHook.ShutdownHookThread   - + SimpleRpcSchedulerFactory
Constructs a SimpleRpcScheduler.
- + SplitLogWorker
This worker is spawned in every regionserver, including master.
- + SplitRequest
Handles processing region splits.
- + SteppingSplitPolicy   - + StoreEngine<SF extends StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends StoreFileManager>
StoreEngine is a factory that can create the objects necessary for HStore to operate.
- + StoreFile
A Store data file.
- + StoreFile.Comparators
Useful comparators for comparing StoreFiles.
- + StoreFile.Comparators.GetBulkTime   - + StoreFile.Comparators.GetFileSize   - + StoreFile.Comparators.GetMaxTimestamp   - + StoreFile.Comparators.GetPathName   - + StoreFile.Comparators.GetSeqId   - + StoreFileInfo
Describe a StoreFile (hfile, reference, link)
- + 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   - + StoreFlusher
Store flusher interface.
- + StoreScanner
Scanner scans both the memstore and the Store.
- + StoreUtils
Utility functions for region server storage layer.
- + StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files for stripe compaction.
- + StripeMultiFileWriter.BoundaryMultiWriter
MultiWriter that separates the cells based on fixed row-key boundaries.
- + StripeMultiFileWriter.SizeMultiWriter
MultiWriter that separates the cells based on target cell number per file and file count.
- + StripeStoreConfig
Configuration class for stripe store and compactions.
- + StripeStoreEngine
The storage engine that implements the stripe-based store/compaction scheme.
- + StripeStoreFileManager
Stripe implementation of StoreFileManager.
- + StripeStoreFileManager.KeyBeforeConcatenatedLists
An extension of ConcatenatedLists that has several peculiar properties.
- + StripeStoreFileManager.State
The state class.
- + StripeStoreFlusher
Stripe implementation of StoreFlusher.
- + StripeStoreFlusher.BoundaryStripeFlushRequest
Stripe flush request wrapper based on boundaries.
- + StripeStoreFlusher.SizeStripeFlushRequest
Stripe flush request wrapper based on size.
- + 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.
- + VersionedSegmentsList
A list of segment managers coupled with the version of the memstore (version at the time it was http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html b/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html index 3950b89..3cd2d9e 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html @@ -129,6 +129,7 @@
  • org.apache.hadoop.hbase.regionserver.CellFlatMap (implements java.util.NavigableMap<K,V>)
  • org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection (implements java.util.Collection<E>)
  • @@ -683,20 +684,20 @@ http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html index 777d49b..b4cd04c 100644 --- a/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/regionserver/querymatcher/package-tree.html @@ -125,9 +125,9 @@
    • java.lang.Enum<E> (implements java.lang.Comparable<T>, java.io.Serializable)
    • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/rest/model/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/rest/model/package-tree.html b/devapidocs/org/apache/hadoop/hbase/rest/model/package-tree.html index dbfbf42..d9efa05 100644 --- a/devapidocs/org/apache/hadoop/hbase/rest/model/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/rest/model/package-tree.html @@ -110,8 +110,8 @@ http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html b/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html index 377757c..8387ff7 100644 --- a/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/security/access/package-tree.html @@ -135,9 +135,9 @@ http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4d2dcb8d/devapidocs/org/apache/hadoop/hbase/security/package-tree.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/security/package-tree.html b/devapidocs/org/apache/hadoop/hbase/security/package-tree.html index dadc344..e40986a 100644 --- a/devapidocs/org/apache/hadoop/hbase/security/package-tree.html +++ b/devapidocs/org/apache/hadoop/hbase/security/package-tree.html @@ -191,9 +191,9 @@